You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@curator.apache.org by ti...@apache.org on 2023/03/13 07:26:19 UTC

[curator] branch master updated (34432073 -> 79edb0e2)

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

tison pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/curator.git


    from 34432073 CURATOR-518: Fix LeaderSelector requeue broken by interruptLeadership (#446)
     new 89df142a CURATOR-661: Use license header checker and add required status
     new 79edb0e2 CURATOR-661: Apply license header reformat

The 2 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../test/resources/log4j.properties => .asf.yaml   | 37 +++++++++----
 .github/workflows/ci.yml                           | 39 ++++++++------
 curator-client/pom.xml                             |  7 ++-
 .../java/org/apache/curator/ConnectionState.java   |  3 +-
 .../curator/CuratorConnectionLossException.java    |  3 +-
 .../org/apache/curator/CuratorZookeeperClient.java |  2 +-
 .../main/java/org/apache/curator/HandleHolder.java |  3 +-
 .../src/main/java/org/apache/curator/Helper.java   |  3 +-
 .../main/java/org/apache/curator/RetryLoop.java    |  3 +-
 .../java/org/apache/curator/RetryLoopImpl.java     |  2 +-
 .../main/java/org/apache/curator/RetryPolicy.java  |  3 +-
 .../main/java/org/apache/curator/RetrySleeper.java |  3 +-
 .../org/apache/curator/SessionFailRetryLoop.java   |  3 +-
 .../apache/curator/SessionFailedRetryPolicy.java   |  3 +-
 .../main/java/org/apache/curator/TimeTrace.java    |  3 +-
 .../curator/connection/ThreadLocalRetryLoop.java   |  3 +-
 .../curator/drivers/AdvancedTracerDriver.java      |  3 +-
 .../org/apache/curator/drivers/EventTrace.java     |  3 +-
 .../org/apache/curator/drivers/OperationTrace.java |  3 +-
 .../org/apache/curator/drivers/TracerDriver.java   |  3 +-
 .../apache/curator/ensemble/EnsembleProvider.java  |  3 +-
 .../ensemble/fixed/FixedEnsembleProvider.java      |  3 +-
 .../retry/BoundedExponentialBackoffRetry.java      |  3 +-
 .../curator/retry/ExponentialBackoffRetry.java     |  3 +-
 .../org/apache/curator/retry/RetryForever.java     |  3 +-
 .../java/org/apache/curator/retry/RetryNTimes.java |  3 +-
 .../org/apache/curator/retry/RetryOneTime.java     |  3 +-
 .../apache/curator/retry/RetryUntilElapsed.java    |  3 +-
 .../org/apache/curator/retry/SleepingRetry.java    |  3 +-
 .../curator/utils/CloseableExecutorService.java    |  2 +-
 .../utils/CloseableScheduledExecutorService.java   |  2 +-
 .../org/apache/curator/utils/CloseableUtils.java   |  2 +-
 .../org/apache/curator/utils/Compatibility.java    |  2 +-
 .../utils/ConfigurableZookeeperFactory.java        |  2 +-
 .../java/org/apache/curator/utils/DebugUtils.java  |  2 +-
 .../apache/curator/utils/DefaultTracerDriver.java  |  3 +-
 .../curator/utils/DefaultZookeeperFactory.java     |  3 +-
 .../java/org/apache/curator/utils/EnsurePath.java  |  2 +-
 .../apache/curator/utils/ExceptionAccumulator.java |  3 +-
 .../apache/curator/utils/InternalACLProvider.java  |  2 +-
 .../curator/utils/NonAdminZookeeperFactory.java    |  3 +-
 .../java/org/apache/curator/utils/PathUtils.java   |  3 +-
 .../java/org/apache/curator/utils/ThreadUtils.java |  3 +-
 .../java/org/apache/curator/utils/ZKPaths.java     |  2 +-
 .../org/apache/curator/utils/ZookeeperFactory.java |  3 +-
 .../test/java/org/apache/curator/BasicTests.java   |  3 +-
 .../java/org/apache/curator/TestEnsurePath.java    |  3 +-
 .../src/test/java/org/apache/curator/TestIs37.java |  3 +-
 .../java/org/apache/curator/TestRetryLoop.java     |  3 +-
 .../apache/curator/TestSessionFailRetryLoop.java   |  3 +-
 .../utils/TestCloseableExecutorService.java        |  2 +-
 .../TestCloseableScheduledExecutorService.java     |  3 +-
 .../java/org/apache/curator/utils/TestZKPaths.java |  2 +-
 curator-client/src/test/resources/log4j.properties |  2 -
 curator-examples/pom.xml                           |  4 +-
 .../src/main/java/async/AsyncExamples.java         |  3 +-
 .../src/main/java/cache/CuratorCacheExample.java   |  2 +-
 .../src/main/java/cache/PathCacheExample.java      |  3 +-
 .../src/main/java/cache/TreeCacheExample.java      |  3 +-
 .../src/main/java/discovery/DiscoveryExample.java  |  3 +-
 .../src/main/java/discovery/ExampleServer.java     |  3 +-
 .../src/main/java/discovery/InstanceDetails.java   |  3 +-
 .../main/java/framework/CreateClientExamples.java  |  3 +-
 .../src/main/java/framework/CrudExamples.java      |  3 +-
 .../main/java/framework/TransactionExamples.java   |  3 +-
 .../src/main/java/leader/ExampleClient.java        |  3 +-
 .../main/java/leader/LeaderSelectorExample.java    |  3 +-
 .../main/java/locking/ExampleClientThatLocks.java  |  3 +-
 .../src/main/java/locking/FakeLimitedResource.java |  3 +-
 .../src/main/java/locking/LockingExample.java      |  3 +-
 .../src/main/java/modeled/ContainerType.java       |  3 +-
 .../main/java/modeled/ModeledCuratorExamples.java  |  3 +-
 .../java/modeled/ModeledCuratorExamplesAlt.java    |  3 +-
 .../src/main/java/modeled/PersonId.java            |  3 +-
 .../src/main/java/modeled/PersonModel.java         |  3 +-
 .../src/main/java/modeled/PersonModelSpec.java     |  3 +-
 curator-examples/src/main/java/pubsub/Clients.java |  3 +-
 .../src/main/java/pubsub/Publisher.java            |  3 +-
 .../src/main/java/pubsub/SubPubTest.java           |  3 +-
 .../src/main/java/pubsub/Subscriber.java           |  3 +-
 .../java/pubsub/messages/LocationAvailable.java    |  3 +-
 .../src/main/java/pubsub/messages/UserCreated.java |  3 +-
 .../src/main/java/pubsub/models/Group.java         |  3 +-
 .../src/main/java/pubsub/models/Instance.java      |  3 +-
 .../src/main/java/pubsub/models/InstanceType.java  |  3 +-
 .../src/main/java/pubsub/models/Message.java       |  3 +-
 .../src/main/java/pubsub/models/Priority.java      |  3 +-
 .../src/main/resources/log4j.properties            |  2 -
 curator-framework/pom.xml                          |  4 +-
 .../org/apache/curator/framework/AuthInfo.java     |  2 +-
 .../apache/curator/framework/CuratorFramework.java |  2 +-
 .../curator/framework/CuratorFrameworkFactory.java |  2 +-
 .../curator/framework/CuratorTempFramework.java    |  3 +-
 .../apache/curator/framework/EnsureContainers.java |  3 +-
 .../framework/WatcherRemoveCuratorFramework.java   |  3 +-
 .../api/ACLBackgroundPathAndBytesable.java         |  3 +-
 .../ACLCreateModeBackgroundPathAndBytesable.java   |  3 +-
 .../api/ACLCreateModePathAndBytesable.java         |  3 +-
 ...CLCreateModeStatBackgroundPathAndBytesable.java |  3 +-
 .../curator/framework/api/ACLPathAndBytesable.java |  3 +-
 .../apache/curator/framework/api/ACLProvider.java  |  3 +-
 .../org/apache/curator/framework/api/ACLable.java  |  3 +-
 .../framework/api/ACLableExistBuilderMain.java     |  2 +-
 .../framework/api/AddStatConfigEnsembleable.java   |  2 +-
 .../curator/framework/api/AddWatchBuilder.java     |  3 +-
 .../curator/framework/api/AddWatchBuilder2.java    |  2 +-
 .../org/apache/curator/framework/api/Addable.java  |  2 +-
 .../curator/framework/api/AsyncReconfigurable.java |  3 +-
 .../curator/framework/api/BackgroundCallback.java  |  3 +-
 .../framework/api/BackgroundEnsembleable.java      |  3 +-
 .../framework/api/BackgroundPathAndBytesable.java  |  3 +-
 .../curator/framework/api/BackgroundPathable.java  |  3 +-
 .../api/BackgroundPathableQuietlyable.java         |  3 +-
 .../framework/api/BackgroundVersionable.java       |  3 +-
 .../curator/framework/api/Backgroundable.java      |  3 +-
 .../curator/framework/api/ChildrenDeletable.java   |  3 +-
 .../apache/curator/framework/api/Compressible.java |  3 +-
 .../curator/framework/api/CompressionProvider.java |  3 +-
 .../framework/api/ConfigureEnsembleable.java       |  2 +-
 .../framework/api/CreateBackgroundModeACLable.java |  3 +-
 .../api/CreateBackgroundModeStatACLable.java       |  3 +-
 .../curator/framework/api/CreateBuilder.java       |  3 +-
 .../curator/framework/api/CreateBuilder2.java      |  3 +-
 .../curator/framework/api/CreateBuilderMain.java   |  3 +-
 .../curator/framework/api/CreateModable.java       |  3 +-
 ...CreateProtectACLCreateModePathAndBytesable.java |  3 +-
 .../apache/curator/framework/api/CuratorEvent.java |  3 +-
 .../curator/framework/api/CuratorEventType.java    |  3 +-
 .../curator/framework/api/CuratorListener.java     |  3 +-
 .../curator/framework/api/CuratorWatcher.java      |  3 +-
 .../curator/framework/api/DataCallbackable.java    |  3 +-
 .../curator/framework/api/Decompressible.java      |  3 +-
 .../curator/framework/api/DeleteBuilder.java       |  3 +-
 .../curator/framework/api/DeleteBuilderMain.java   |  3 +-
 .../apache/curator/framework/api/Ensembleable.java |  3 +-
 .../framework/api/ErrorListenerEnsembleable.java   |  3 +-
 .../api/ErrorListenerMultiTransactionMain.java     |  3 +-
 .../api/ErrorListenerPathAndBytesable.java         |  3 +-
 .../framework/api/ErrorListenerPathable.java       |  3 +-
 .../api/ErrorListenerReconfigBuilderMain.java      |  3 +-
 .../curator/framework/api/ExistsBuilder.java       |  2 +-
 .../curator/framework/api/ExistsBuilderMain.java   |  3 +-
 .../curator/framework/api/GetACLBuilder.java       |  3 +-
 .../curator/framework/api/GetChildrenBuilder.java  |  3 +-
 .../curator/framework/api/GetConfigBuilder.java    |  2 +-
 .../curator/framework/api/GetDataBuilder.java      |  3 +-
 .../api/GetDataWatchBackgroundStatable.java        |  3 +-
 .../curator/framework/api/Guaranteeable.java       |  3 +-
 .../framework/api/GuaranteeableDeletable.java      |  3 +-
 .../curator/framework/api/Idempotentable.java      |  3 +-
 .../framework/api/JoinStatConfigEnsembleable.java  |  2 +-
 .../org/apache/curator/framework/api/Joinable.java |  2 +-
 .../framework/api/LeaveStatConfigEnsembleable.java |  2 +-
 .../apache/curator/framework/api/Leaveable.java    |  2 +-
 .../apache/curator/framework/api/Membersable.java  |  2 +-
 .../curator/framework/api/ParentACLable.java       |  3 +-
 .../curator/framework/api/PathAndBytesable.java    |  3 +-
 .../org/apache/curator/framework/api/Pathable.java |  3 +-
 .../api/ProtectACLCreateModePathAndBytesable.java  |  3 +-
 .../ProtectACLCreateModeStatPathAndBytesable.java  |  3 +-
 .../org/apache/curator/framework/api/Quietly.java  |  3 +-
 .../curator/framework/api/ReconfigBuilder.java     |  2 +-
 .../curator/framework/api/ReconfigBuilderMain.java |  2 +-
 .../framework/api/RemoveWatchesBuilder.java        | 37 ++++++-------
 .../curator/framework/api/RemoveWatchesLocal.java  | 37 ++++++-------
 .../curator/framework/api/RemoveWatchesType.java   | 37 ++++++-------
 .../curator/framework/api/SetACLBuilder.java       |  3 +-
 .../api/SetDataBackgroundVersionable.java          |  3 +-
 .../curator/framework/api/SetDataBuilder.java      |  3 +-
 .../framework/api/StatConfigureEnsembleable.java   |  2 +-
 .../apache/curator/framework/api/StatPathable.java |  3 +-
 .../org/apache/curator/framework/api/Statable.java |  3 +-
 .../apache/curator/framework/api/SyncBuilder.java  |  3 +-
 .../curator/framework/api/TempGetDataBuilder.java  |  3 +-
 .../framework/api/UnhandledErrorListener.java      |  3 +-
 .../framework/api/VersionPathAndBytesable.java     |  3 +-
 .../apache/curator/framework/api/Versionable.java  |  3 +-
 .../framework/api/WatchBackgroundEnsembleable.java |  3 +-
 .../curator/framework/api/WatchPathable.java       |  3 +-
 .../apache/curator/framework/api/Watchable.java    |  3 +-
 .../curator/framework/api/WatchableBase.java       |  3 +-
 .../curator/framework/api/WatchesBuilder.java      |  2 +-
 .../api/transaction/CuratorMultiTransaction.java   |  3 +-
 .../transaction/CuratorMultiTransactionMain.java   |  3 +-
 .../framework/api/transaction/CuratorOp.java       |  3 +-
 .../api/transaction/CuratorTransaction.java        |  3 +-
 .../api/transaction/CuratorTransactionBridge.java  |  3 +-
 .../api/transaction/CuratorTransactionFinal.java   |  3 +-
 .../api/transaction/CuratorTransactionResult.java  |  2 +-
 .../framework/api/transaction/OperationType.java   |  3 +-
 .../api/transaction/TransactionCheckBuilder.java   |  3 +-
 .../api/transaction/TransactionCreateBuilder.java  |  3 +-
 .../api/transaction/TransactionCreateBuilder2.java |  3 +-
 .../api/transaction/TransactionDeleteBuilder.java  |  3 +-
 .../framework/api/transaction/TransactionOp.java   |  3 +-
 .../api/transaction/TransactionSetDataBuilder.java |  3 +-
 .../framework/api/transaction/TypeAndPath.java     |  3 +-
 .../org/apache/curator/framework/imps/ACLing.java  |  3 +-
 .../framework/imps/AddWatchBuilderImpl.java        |  2 +-
 .../framework/imps/BackgroundOperation.java        |  3 +-
 .../curator/framework/imps/BackgroundSyncImpl.java |  3 +-
 .../curator/framework/imps/Backgrounding.java      |  2 +-
 .../curator/framework/imps/CreateBuilderImpl.java  |  2 +-
 .../curator/framework/imps/CuratorEventImpl.java   |  2 +-
 .../framework/imps/CuratorFrameworkImpl.java       |  2 +-
 .../framework/imps/CuratorFrameworkState.java      |  3 +-
 .../imps/CuratorMultiTransactionImpl.java          |  2 +-
 .../imps/CuratorMultiTransactionRecord.java        |  2 +-
 .../framework/imps/CuratorTempFrameworkImpl.java   |  3 +-
 .../framework/imps/CuratorTransactionImpl.java     |  2 +-
 .../curator/framework/imps/DefaultACLProvider.java |  3 +-
 .../curator/framework/imps/DeleteBuilderImpl.java  |  3 +-
 .../curator/framework/imps/EnsembleTracker.java    |  2 +-
 .../curator/framework/imps/ExistsBuilderImpl.java  |  3 +-
 .../framework/imps/ExtractingCuratorOp.java        |  3 +-
 .../framework/imps/FailedDeleteManager.java        |  3 +-
 .../framework/imps/FailedOperationManager.java     |  3 +-
 .../framework/imps/FailedRemoveWatchManager.java   |  3 +-
 .../FindAndDeleteProtectedNodeInBackground.java    |  3 +-
 .../curator/framework/imps/GetACLBuilderImpl.java  |  3 +-
 .../framework/imps/GetChildrenBuilderImpl.java     |  3 +-
 .../framework/imps/GetConfigBuilderImpl.java       |  2 +-
 .../curator/framework/imps/GetDataBuilderImpl.java |  3 +-
 .../framework/imps/GzipCompressionProvider.java    |  3 +-
 .../curator/framework/imps/IdempotentUtils.java    |  3 +-
 .../framework/imps/InternalConnectionHandler.java  |  3 +-
 .../curator/framework/imps/NamespaceFacade.java    |  3 +-
 .../framework/imps/NamespaceFacadeCache.java       |  3 +-
 .../curator/framework/imps/NamespaceImpl.java      |  3 +-
 .../framework/imps/NamespaceWatchedEvent.java      |  3 +-
 .../curator/framework/imps/NamespaceWatcher.java   |  3 +-
 .../curator/framework/imps/OperationAndData.java   |  2 +-
 .../curator/framework/imps/PathAndBytes.java       |  3 +-
 .../curator/framework/imps/ProtectedMode.java      |  2 +-
 .../curator/framework/imps/ProtectedUtils.java     |  3 +-
 .../framework/imps/ReconfigBuilderImpl.java        |  2 +-
 .../framework/imps/RemoveWatchesBuilderImpl.java   | 37 ++++++-------
 .../curator/framework/imps/SetACLBuilderImpl.java  |  3 +-
 .../curator/framework/imps/SetDataBuilderImpl.java |  3 +-
 .../imps/StandardInternalConnectionHandler.java    |  3 +-
 .../curator/framework/imps/SyncBuilderImpl.java    |  3 +-
 .../framework/imps/TempGetDataBuilderImpl.java     |  3 +-
 .../curator/framework/imps/TransactionOpImpl.java  |  3 +-
 .../framework/imps/WatcherRemovalFacade.java       |  2 +-
 .../framework/imps/WatcherRemovalManager.java      |  3 +-
 .../curator/framework/imps/WatchesBuilderImpl.java |  2 +-
 .../apache/curator/framework/imps/Watching.java    |  2 +-
 .../curator/framework/listen/Listenable.java       |  3 +-
 .../curator/framework/listen/ListenerEntry.java    |  3 +-
 .../curator/framework/listen/ListenerManager.java  |  3 +-
 .../framework/listen/MappingListenerManager.java   |  3 +-
 .../framework/listen/StandardListenerManager.java  |  3 +-
 .../framework/listen/UnaryListenerManager.java     |  3 +-
 .../framework/schema/DefaultSchemaValidator.java   |  3 +-
 .../apache/curator/framework/schema/Schema.java    |  3 +-
 .../curator/framework/schema/SchemaBuilder.java    |  3 +-
 .../apache/curator/framework/schema/SchemaSet.java |  3 +-
 .../curator/framework/schema/SchemaSetLoader.java  |  3 +-
 .../curator/framework/schema/SchemaValidator.java  |  3 +-
 .../curator/framework/schema/SchemaViolation.java  |  3 +-
 .../curator/framework/state/CircuitBreaker.java    |  3 +-
 .../CircuitBreakingConnectionStateListener.java    |  3 +-
 .../framework/state/CircuitBreakingManager.java    |  3 +-
 .../curator/framework/state/ConnectionState.java   |  3 +-
 .../state/ConnectionStateErrorPolicy.java          |  3 +-
 .../framework/state/ConnectionStateListener.java   |  3 +-
 .../ConnectionStateListenerManagerFactory.java     |  3 +-
 .../framework/state/ConnectionStateManager.java    |  2 +-
 .../state/SessionConnectionStateErrorPolicy.java   |  3 +-
 .../state/StandardConnectionStateErrorPolicy.java  |  3 +-
 .../framework/ensemble/TestEnsembleProvider.java   |  3 +-
 .../framework/imps/TestBlockUntilConnected.java    |  2 +-
 .../curator/framework/imps/TestCleanState.java     |  3 +-
 .../curator/framework/imps/TestCompression.java    |  3 +-
 .../imps/TestCompressionInTransactionNew.java      |  3 +-
 .../imps/TestCompressionInTransactionOld.java      |  3 +-
 .../apache/curator/framework/imps/TestCreate.java  |  3 +-
 .../framework/imps/TestCreateReturningStat.java    | 37 ++++++-------
 .../apache/curator/framework/imps/TestDelete.java  |  3 +-
 .../imps/TestEnabledSessionExpiredState.java       |  3 +-
 .../framework/imps/TestEnsureContainers.java       |  3 +-
 .../curator/framework/imps/TestExistsBuilder.java  |  3 +-
 .../framework/imps/TestFailedDeleteManager.java    |  3 +-
 .../curator/framework/imps/TestFramework.java      |  3 +-
 .../framework/imps/TestFrameworkBackground.java    |  2 +-
 .../curator/framework/imps/TestFrameworkEdges.java |  2 +-
 .../imps/TestGzipCompressionProvider.java          |  3 +-
 .../curator/framework/imps/TestMultiClient.java    |  3 +-
 .../framework/imps/TestNamespaceFacade.java        |  3 +-
 .../curator/framework/imps/TestNeverConnected.java |  2 +-
 .../curator/framework/imps/TestReadOnly.java       |  2 +-
 .../framework/imps/TestReconfiguration.java        |  2 +-
 .../apache/curator/framework/imps/TestSetData.java |  3 +-
 .../curator/framework/imps/TestTempFramework.java  |  3 +-
 .../framework/imps/TestTransactionsNew.java        |  2 +-
 .../framework/imps/TestTransactionsOld.java        |  3 +-
 .../curator/framework/imps/TestTtlNodes.java       |  3 +-
 .../framework/imps/TestWatcherIdentity.java        |  3 +-
 .../framework/imps/TestWatcherRemovalManager.java  |  3 +-
 .../curator/framework/imps/TestWatchesBuilder.java | 37 ++++++-------
 .../curator/framework/imps/TestWithCluster.java    |  3 +-
 .../curator/framework/schema/TestSchema.java       |  3 +-
 .../framework/state/TestCircuitBreaker.java        |  3 +-
 ...TestCircuitBreakingConnectionStateListener.java |  3 +-
 .../state/TestConnectionStateManager.java          |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-recipes/pom.xml                            |  4 +-
 .../recipes/AfterConnectionEstablished.java        |  2 +-
 .../framework/recipes/atomic/AtomicStats.java      |  3 +-
 .../framework/recipes/atomic/AtomicValue.java      |  3 +-
 .../recipes/atomic/CachedAtomicInteger.java        |  3 +-
 .../framework/recipes/atomic/CachedAtomicLong.java |  3 +-
 .../recipes/atomic/DistributedAtomicInteger.java   |  3 +-
 .../recipes/atomic/DistributedAtomicLong.java      |  3 +-
 .../recipes/atomic/DistributedAtomicNumber.java    |  2 +-
 .../recipes/atomic/DistributedAtomicValue.java     |  3 +-
 .../framework/recipes/atomic/MakeValue.java        |  3 +-
 .../recipes/atomic/MutableAtomicValue.java         |  3 +-
 .../framework/recipes/atomic/PromotedToLock.java   |  3 +-
 .../recipes/barriers/DistributedBarrier.java       |  3 +-
 .../recipes/barriers/DistributedDoubleBarrier.java |  3 +-
 .../curator/framework/recipes/cache/ChildData.java |  3 +-
 .../cache/CompatibleCuratorCacheBridge.java        |  3 +-
 .../framework/recipes/cache/CuratorCache.java      |  2 +-
 .../recipes/cache/CuratorCacheAccessor.java        |  2 +-
 .../recipes/cache/CuratorCacheBridge.java          |  3 +-
 .../recipes/cache/CuratorCacheBridgeBuilder.java   |  2 +-
 .../cache/CuratorCacheBridgeBuilderImpl.java       |  2 +-
 .../recipes/cache/CuratorCacheBuilder.java         |  2 +-
 .../recipes/cache/CuratorCacheBuilderImpl.java     |  2 +-
 .../framework/recipes/cache/CuratorCacheImpl.java  |  3 +-
 .../recipes/cache/CuratorCacheListener.java        |  2 +-
 .../recipes/cache/CuratorCacheListenerBuilder.java |  2 +-
 .../cache/CuratorCacheListenerBuilderImpl.java     |  2 +-
 .../recipes/cache/CuratorCacheStorage.java         |  3 +-
 .../recipes/cache/DefaultTreeCacheSelector.java    |  3 +-
 .../framework/recipes/cache/EventOperation.java    |  3 +-
 .../framework/recipes/cache/GetDataOperation.java  |  3 +-
 .../curator/framework/recipes/cache/NodeCache.java |  3 +-
 .../framework/recipes/cache/NodeCacheListener.java |  3 +-
 .../recipes/cache/NodeCacheListenerWrapper.java    |  2 +-
 .../curator/framework/recipes/cache/Operation.java |  3 +-
 .../framework/recipes/cache/PathChildrenCache.java |  2 +-
 .../recipes/cache/PathChildrenCacheEvent.java      |  3 +-
 .../recipes/cache/PathChildrenCacheListener.java   |  3 +-
 .../cache/PathChildrenCacheListenerWrapper.java    |  2 +-
 .../recipes/cache/PathChildrenCacheMode.java       |  3 +-
 .../framework/recipes/cache/RefreshOperation.java  |  3 +-
 .../recipes/cache/StandardCuratorCacheStorage.java |  2 +-
 .../curator/framework/recipes/cache/TreeCache.java |  2 +-
 .../framework/recipes/cache/TreeCacheEvent.java    |  2 +-
 .../framework/recipes/cache/TreeCacheIterator.java |  3 +-
 .../framework/recipes/cache/TreeCacheListener.java |  2 +-
 .../recipes/cache/TreeCacheListenerWrapper.java    |  2 +-
 .../framework/recipes/cache/TreeCacheSelector.java |  3 +-
 .../recipes/leader/CancelLeadershipException.java  |  3 +-
 .../framework/recipes/leader/LeaderLatch.java      |  2 +-
 .../recipes/leader/LeaderLatchListener.java        |  3 +-
 .../framework/recipes/leader/LeaderSelector.java   |  2 +-
 .../recipes/leader/LeaderSelectorListener.java     |  3 +-
 .../leader/LeaderSelectorListenerAdapter.java      |  3 +-
 .../framework/recipes/leader/Participant.java      |  3 +-
 .../framework/recipes/locks/InterProcessLock.java  |  3 +-
 .../recipes/locks/InterProcessMultiLock.java       |  3 +-
 .../framework/recipes/locks/InterProcessMutex.java |  2 +-
 .../recipes/locks/InterProcessReadWriteLock.java   |  3 +-
 .../recipes/locks/InterProcessSemaphore.java       |  3 +-
 .../recipes/locks/InterProcessSemaphoreMutex.java  |  3 +-
 .../recipes/locks/InterProcessSemaphoreV2.java     |  2 +-
 .../curator/framework/recipes/locks/Lease.java     |  3 +-
 .../framework/recipes/locks/LockInternals.java     |  3 +-
 .../recipes/locks/LockInternalsDriver.java         |  3 +-
 .../recipes/locks/LockInternalsSorter.java         |  3 +-
 .../curator/framework/recipes/locks/Locker.java    |  3 +-
 .../framework/recipes/locks/PredicateResults.java  |  3 +-
 .../curator/framework/recipes/locks/Revocable.java |  3 +-
 .../recipes/locks/RevocationListener.java          |  3 +-
 .../framework/recipes/locks/RevocationSpec.java    |  3 +-
 .../curator/framework/recipes/locks/Revoker.java   |  3 +-
 .../recipes/locks/StandardLockInternalsDriver.java |  3 +-
 .../framework/recipes/nodes/GroupMember.java       |  3 +-
 .../recipes/nodes/PersistentEphemeralNode.java     |  2 +-
 .../framework/recipes/nodes/PersistentNode.java    |  2 +-
 .../recipes/nodes/PersistentNodeListener.java      |  2 +-
 .../framework/recipes/nodes/PersistentTtlNode.java |  3 +-
 .../recipes/queue/BlockingQueueConsumer.java       |  3 +-
 .../framework/recipes/queue/ChildrenCache.java     |  3 +-
 .../recipes/queue/DistributedDelayQueue.java       |  3 +-
 .../recipes/queue/DistributedIdQueue.java          |  3 +-
 .../recipes/queue/DistributedPriorityQueue.java    |  3 +-
 .../framework/recipes/queue/DistributedQueue.java  |  3 +-
 .../curator/framework/recipes/queue/ErrorMode.java |  3 +-
 .../framework/recipes/queue/ItemSerializer.java    |  3 +-
 .../curator/framework/recipes/queue/MultiItem.java |  3 +-
 .../framework/recipes/queue/QueueAllocator.java    |  3 +-
 .../curator/framework/recipes/queue/QueueBase.java |  3 +-
 .../framework/recipes/queue/QueueBuilder.java      |  3 +-
 .../framework/recipes/queue/QueueConsumer.java     |  3 +-
 .../framework/recipes/queue/QueuePutListener.java  |  3 +-
 .../framework/recipes/queue/QueueSafety.java       |  3 +-
 .../framework/recipes/queue/QueueSerializer.java   |  3 +-
 .../framework/recipes/queue/QueueSharder.java      |  3 +-
 .../recipes/queue/QueueSharderPolicies.java        |  3 +-
 .../recipes/queue/SimpleDistributedQueue.java      |  3 +-
 .../framework/recipes/shared/SharedCount.java      |  3 +-
 .../recipes/shared/SharedCountListener.java        |  3 +-
 .../recipes/shared/SharedCountReader.java          |  3 +-
 .../framework/recipes/shared/SharedValue.java      |  2 +-
 .../recipes/shared/SharedValueListener.java        |  3 +-
 .../recipes/shared/SharedValueReader.java          |  3 +-
 .../framework/recipes/shared/VersionedValue.java   |  3 +-
 .../framework/recipes/watch/PersistentWatcher.java |  3 +-
 .../connection/TestThreadLocalRetryLoop.java       |  3 +-
 .../framework/client/TestBackgroundStates.java     |  2 +-
 .../TestResetConnectionWithBackgroundFailure.java  |  2 +-
 .../recipes/atomic/TestCachedAtomicCounter.java    |  3 +-
 .../recipes/atomic/TestDistributedAtomicLong.java  |  3 +-
 .../recipes/barriers/TestDistributedBarrier.java   |  3 +-
 .../barriers/TestDistributedDoubleBarrier.java     |  3 +-
 .../framework/recipes/cache/BaseTestTreeCache.java |  2 +-
 .../framework/recipes/cache/TestCuratorCache.java  |  2 +-
 .../recipes/cache/TestCuratorCacheBridge.java      |  2 +-
 .../recipes/cache/TestCuratorCacheConsistency.java |  2 +-
 .../recipes/cache/TestCuratorCacheEdges.java       |  2 +-
 .../cache/TestCuratorCacheEventOrdering.java       |  3 +-
 .../recipes/cache/TestCuratorCacheWrappers.java    |  2 +-
 .../framework/recipes/cache/TestEventOrdering.java |  3 +-
 .../framework/recipes/cache/TestNodeCache.java     |  3 +-
 .../recipes/cache/TestPathChildrenCache.java       |  2 +-
 .../cache/TestPathChildrenCacheEventOrdering.java  |  3 +-
 .../cache/TestPathChildrenCacheInCluster.java      |  3 +-
 .../framework/recipes/cache/TestTreeCache.java     |  2 +-
 .../recipes/cache/TestTreeCacheEventOrdering.java  |  3 +-
 .../cache/TestTreeCacheIteratorAndSize.java        |  3 +-
 .../recipes/cache/TestTreeCacheRandomTree.java     |  2 +-
 .../recipes/cache/TestWrappedNodeCache.java        |  3 +-
 .../recipes/leader/ChaosMonkeyCnxnFactory.java     |  2 +-
 .../framework/recipes/leader/TestLeaderAcls.java   |  2 +-
 .../framework/recipes/leader/TestLeaderLatch.java  |  2 +-
 .../recipes/leader/TestLeaderLatchCluster.java     |  3 +-
 .../recipes/leader/TestLeaderSelector.java         |  2 +-
 .../recipes/leader/TestLeaderSelectorCluster.java  |  3 +-
 .../recipes/leader/TestLeaderSelectorEdges.java    |  2 +-
 .../leader/TestLeaderSelectorParticipants.java     |  3 +-
 .../leader/TestLeaderSelectorWithExecutor.java     |  3 +-
 .../curator/framework/recipes/locks/Counter.java   |  3 +-
 .../framework/recipes/locks/SemaphoreClient.java   |  3 +-
 .../curator/framework/recipes/locks/Stepper.java   |  3 +-
 .../recipes/locks/TestInterProcessMultiMutex.java  |  3 +-
 .../recipes/locks/TestInterProcessMutex.java       |  2 +-
 .../recipes/locks/TestInterProcessMutexBase.java   |  2 +-
 .../locks/TestInterProcessReadWriteLock.java       |  2 +-
 .../recipes/locks/TestInterProcessSemaphore.java   |  2 +-
 .../locks/TestInterProcessSemaphoreCluster.java    |  3 +-
 .../locks/TestInterProcessSemaphoreMutex.java      |  3 +-
 .../framework/recipes/locks/TestLockACLs.java      |  2 +-
 .../locks/TestLockCleanlinessWithFaults.java       |  3 +-
 .../framework/recipes/nodes/TestGroupMember.java   |  3 +-
 .../recipes/nodes/TestPersistentEphemeralNode.java |  3 +-
 .../nodes/TestPersistentEphemeralNodeListener.java |  2 +-
 .../recipes/nodes/TestPersistentNode.java          |  3 +-
 .../recipes/nodes/TestPersistentTtlNode.java       |  3 +-
 .../recipes/queue/QueueItemSerializer.java         |  3 +-
 .../framework/recipes/queue/QueueTestProducer.java |  3 +-
 .../recipes/queue/TestBoundedDistributedQueue.java |  3 +-
 .../recipes/queue/TestDistributedDelayQueue.java   |  3 +-
 .../recipes/queue/TestDistributedIdQueue.java      |  3 +-
 .../queue/TestDistributedPriorityQueue.java        |  3 +-
 .../recipes/queue/TestDistributedQueue.java        |  3 +-
 .../recipes/queue/TestLongNetworkPartition.java    |  3 +-
 .../framework/recipes/queue/TestQueueItem.java     |  3 +-
 .../framework/recipes/queue/TestQueueSharder.java  |  3 +-
 .../recipes/queue/TestSimpleDistributedQueue.java  |  3 +-
 .../framework/recipes/shared/TestSharedCount.java  |  2 +-
 .../recipes/watch/TestPersistentWatcher.java       |  2 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-test-zk35/pom.xml                          |  8 ++-
 .../curator/framework/TestCompatibility.java       |  3 +-
 .../java/org/apache/curator/zk35/TestIs35.java     |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-test-zk36/pom.xml                          |  8 ++-
 .../java/org/apache/curator/zk36/TestIs36.java     |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-test/pom.xml                               |  4 +-
 .../org/apache/curator/test/BaseClassForTests.java |  2 +-
 .../org/apache/curator/test/Compatibility.java     |  3 +-
 .../curator/test/DelegatingExecutorService.java    |  3 +-
 .../org/apache/curator/test/DirectoryUtils.java    |  3 +-
 .../test/ExecuteCalledWatchingExecutorService.java |  3 +-
 .../curator/test/FailedServerStartException.java   |  3 +-
 .../java/org/apache/curator/test/InstanceSpec.java |  2 +-
 .../java/org/apache/curator/test/KillSession.java  |  3 +-
 .../apache/curator/test/QuorumConfigBuilder.java   |  2 +-
 .../curator/test/QuorumPeerConfigBuilder.java      |  2 +-
 .../java/org/apache/curator/test/ServerHelper.java |  3 +-
 .../org/apache/curator/test/TestingCluster.java    |  3 +-
 .../apache/curator/test/TestingQuorumPeerMain.java |  3 +-
 .../org/apache/curator/test/TestingServer.java     |  2 +-
 .../apache/curator/test/TestingZooKeeperMain.java  |  2 +-
 .../curator/test/TestingZooKeeperServer.java       |  2 +-
 .../main/java/org/apache/curator/test/Timing.java  |  2 +-
 .../org/apache/curator/test/WatchersDebug.java     |  3 +-
 .../org/apache/curator/test/ZooKeeperMainFace.java |  3 +-
 .../test/ZooKeeperServerEmbeddedAdapter.java       |  2 +-
 .../test/compatibility/CuratorTestBase.java        |  3 +-
 .../apache/curator/test/compatibility/Timing2.java |  2 +-
 .../curator/test/TestQuorumConfigBuilder.java      |  3 +-
 .../org/apache/curator/test/TestTestingServer.java |  3 +-
 curator-x-async/pom.xml                            |  4 +-
 .../curator/x/async/AsyncCuratorFramework.java     |  3 +-
 .../curator/x/async/AsyncEventException.java       |  3 +-
 .../org/apache/curator/x/async/AsyncResult.java    |  3 +-
 .../org/apache/curator/x/async/AsyncStage.java     |  3 +-
 .../org/apache/curator/x/async/AsyncWrappers.java  |  3 +-
 .../java/org/apache/curator/x/async/WatchMode.java |  3 +-
 .../curator/x/async/api/AsyncCreateBuilder.java    |  3 +-
 .../x/async/api/AsyncCuratorFrameworkDsl.java      |  3 +-
 .../curator/x/async/api/AsyncDeleteBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncEnsemblable.java      |  3 +-
 .../curator/x/async/api/AsyncExistsBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncGetACLBuilder.java    |  3 +-
 .../x/async/api/AsyncGetChildrenBuilder.java       |  3 +-
 .../curator/x/async/api/AsyncGetConfigBuilder.java |  3 +-
 .../curator/x/async/api/AsyncGetDataBuilder.java   |  3 +-
 .../curator/x/async/api/AsyncMultiTransaction.java |  3 +-
 .../curator/x/async/api/AsyncPathAndBytesable.java |  2 +-
 .../apache/curator/x/async/api/AsyncPathable.java  |  3 +-
 .../curator/x/async/api/AsyncReconfigBuilder.java  |  3 +-
 .../x/async/api/AsyncRemoveWatchesBuilder.java     |  3 +-
 .../curator/x/async/api/AsyncSetACLBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncSetDataBuilder.java   |  3 +-
 .../curator/x/async/api/AsyncSyncBuilder.java      |  3 +-
 .../x/async/api/AsyncTransactionCheckBuilder.java  |  3 +-
 .../x/async/api/AsyncTransactionCreateBuilder.java |  2 +-
 .../x/async/api/AsyncTransactionDeleteBuilder.java |  3 +-
 .../curator/x/async/api/AsyncTransactionOp.java    |  3 +-
 .../async/api/AsyncTransactionSetDataBuilder.java  |  3 +-
 .../curator/x/async/api/AsyncWatchBuilder.java     |  2 +-
 .../curator/x/async/api/AsyncWatchBuilder2.java    |  2 +-
 .../apache/curator/x/async/api/CreateOption.java   |  3 +-
 .../apache/curator/x/async/api/DeleteOption.java   |  3 +-
 .../apache/curator/x/async/api/ExistsOption.java   |  3 +-
 .../curator/x/async/api/RemoveWatcherOption.java   |  3 +-
 .../async/api/WatchableAsyncCuratorFramework.java  |  3 +-
 .../x/async/details/AsyncCreateBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncCuratorFrameworkImpl.java |  3 +-
 .../x/async/details/AsyncDeleteBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncExistsBuilderImpl.java    |  3 +-
 .../async/details/AsyncGetChildrenBuilderImpl.java |  3 +-
 .../x/async/details/AsyncGetConfigBuilderImpl.java |  3 +-
 .../x/async/details/AsyncGetDataBuilderImpl.java   |  3 +-
 .../x/async/details/AsyncReconfigBuilderImpl.java  |  3 +-
 .../details/AsyncRemoveWatchesBuilderImpl.java     |  3 +-
 .../curator/x/async/details/AsyncResultImpl.java   |  3 +-
 .../x/async/details/AsyncSetACLBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncSetDataBuilderImpl.java   |  3 +-
 .../x/async/details/AsyncTransactionOpImpl.java    |  3 +-
 .../x/async/details/AsyncWatchBuilderImpl.java     |  2 +-
 .../curator/x/async/details/BackgroundProc.java    |  3 +-
 .../curator/x/async/details/BackgroundProcs.java   |  3 +-
 .../curator/x/async/details/BuilderCommon.java     |  3 +-
 .../apache/curator/x/async/details/Filters.java    |  3 +-
 .../curator/x/async/details/InternalCallback.java  |  3 +-
 .../curator/x/async/details/InternalWatcher.java   |  3 +-
 .../curator/x/async/migrations/Migration.java      |  3 +-
 .../x/async/migrations/MigrationException.java     |  3 +-
 .../x/async/migrations/MigrationManager.java       |  3 +-
 .../curator/x/async/migrations/MigrationSet.java   |  3 +-
 .../x/async/modeled/JacksonModelSerializer.java    |  3 +-
 .../curator/x/async/modeled/ModelSerializer.java   |  3 +-
 .../apache/curator/x/async/modeled/ModelSpec.java  |  3 +-
 .../curator/x/async/modeled/ModelSpecBuilder.java  |  3 +-
 .../curator/x/async/modeled/ModeledFramework.java  |  3 +-
 .../x/async/modeled/ModeledFrameworkBuilder.java   |  3 +-
 .../curator/x/async/modeled/ModeledOptions.java    |  3 +-
 .../apache/curator/x/async/modeled/NodeName.java   |  3 +-
 .../apache/curator/x/async/modeled/Resolvable.java |  3 +-
 .../org/apache/curator/x/async/modeled/ZNode.java  |  3 +-
 .../org/apache/curator/x/async/modeled/ZPath.java  |  3 +-
 .../modeled/cached/CachedModeledFramework.java     |  3 +-
 .../x/async/modeled/cached/ModeledCache.java       |  3 +-
 .../async/modeled/cached/ModeledCacheListener.java |  3 +-
 .../details/CachedModeledFrameworkImpl.java        |  3 +-
 .../x/async/modeled/details/ModelSpecImpl.java     |  3 +-
 .../x/async/modeled/details/ModelStage.java        |  3 +-
 .../x/async/modeled/details/ModeledCacheImpl.java  |  3 +-
 .../modeled/details/ModeledFrameworkImpl.java      |  3 +-
 .../details/VersionedModeledFrameworkImpl.java     |  3 +-
 .../curator/x/async/modeled/details/ZNodeImpl.java |  3 +-
 .../curator/x/async/modeled/details/ZPathImpl.java |  3 +-
 .../x/async/modeled/typed/TypedModelSpec.java      |  3 +-
 .../x/async/modeled/typed/TypedModelSpec0.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec10.java    |  3 +-
 .../x/async/modeled/typed/TypedModelSpec2.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec3.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec4.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec5.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec6.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec7.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec8.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec9.java     |  3 +-
 .../async/modeled/typed/TypedModeledFramework.java |  3 +-
 .../modeled/typed/TypedModeledFramework0.java      |  3 +-
 .../modeled/typed/TypedModeledFramework10.java     |  3 +-
 .../modeled/typed/TypedModeledFramework2.java      |  3 +-
 .../modeled/typed/TypedModeledFramework3.java      |  3 +-
 .../modeled/typed/TypedModeledFramework4.java      |  3 +-
 .../modeled/typed/TypedModeledFramework5.java      |  3 +-
 .../modeled/typed/TypedModeledFramework6.java      |  3 +-
 .../modeled/typed/TypedModeledFramework7.java      |  3 +-
 .../modeled/typed/TypedModeledFramework8.java      |  3 +-
 .../modeled/typed/TypedModeledFramework9.java      |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath.java  |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath0.java |  3 +-
 .../x/async/modeled/typed/TypedZPath10.java        |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath2.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath3.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath4.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath5.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath6.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath7.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath8.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath9.java |  3 +-
 .../x/async/modeled/versioned/Versioned.java       |  3 +-
 .../versioned/VersionedModeledFramework.java       |  3 +-
 .../curator/framework/imps/TestAddWatch.java       |  3 +-
 .../curator/framework/imps/TestFramework.java      |  3 +-
 .../framework/imps/TestFrameworkBackground.java    |  3 +-
 .../x/async/CompletableBaseClassForTests.java      |  3 +-
 .../apache/curator/x/async/TestAsyncWrappers.java  |  3 +-
 .../curator/x/async/TestBasicOperations.java       |  3 +-
 .../x/async/migrations/TestMigrationManager.java   |  3 +-
 .../curator/x/async/migrations/models/ModelV1.java |  3 +-
 .../curator/x/async/migrations/models/ModelV2.java |  3 +-
 .../curator/x/async/migrations/models/ModelV3.java |  3 +-
 .../async/modeled/TestCachedModeledFramework.java  |  3 +-
 .../x/async/modeled/TestModeledFramework.java      |  2 +-
 .../x/async/modeled/TestModeledFrameworkBase.java  |  3 +-
 .../apache/curator/x/async/modeled/TestZPath.java  |  3 +-
 .../curator/x/async/modeled/models/TestModel.java  |  3 +-
 .../x/async/modeled/models/TestNewerModel.java     |  3 +-
 .../x/async/modeled/models/TestSimpleModel.java    |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-x-discovery-server/pom.xml                 |  4 +-
 .../server/contexts/GenericDiscoveryContext.java   |  3 +-
 .../server/contexts/IntegerDiscoveryContext.java   |  3 +-
 .../server/contexts/MapDiscoveryContext.java       |  3 +-
 .../server/contexts/StringDiscoveryContext.java    |  3 +-
 .../entity/JsonServiceInstanceMarshaller.java      |  3 +-
 .../entity/JsonServiceInstancesMarshaller.java     |  3 +-
 .../server/entity/JsonServiceNamesMarshaller.java  |  3 +-
 .../discovery/server/entity/ServiceInstances.java  |  3 +-
 .../x/discovery/server/entity/ServiceNames.java    |  3 +-
 .../x/discovery/server/rest/DiscoveryContext.java  |  3 +-
 .../x/discovery/server/rest/DiscoveryResource.java |  3 +-
 .../x/discovery/server/rest/InstanceCleanup.java   |  3 +-
 .../server/jetty_jersey/MapDiscoveryResource.java  |  3 +-
 .../server/jetty_jersey/ServiceDetails.java        |  3 +-
 .../ServiceDetailsDiscoveryContext.java            |  3 +-
 .../ServiceDetailsDiscoveryResource.java           |  3 +-
 .../jetty_jersey/StringDiscoveryResource.java      |  3 +-
 .../server/jetty_jersey/TestMapsWithJersey.java    |  3 +-
 .../jetty_jersey/TestObjectPayloadWithJersey.java  |  3 +-
 .../server/jetty_jersey/TestStringsWithJersey.java |  3 +-
 .../server/jetty_resteasy/RestEasyApplication.java |  3 +-
 .../server/jetty_resteasy/RestEasySingletons.java  |  3 +-
 .../jetty_resteasy/StringDiscoveryResource.java    |  3 +-
 .../jetty_resteasy/TestStringsWithRestEasy.java    |  3 +-
 .../server/mocks/MockServiceDiscovery.java         |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 curator-x-discovery/pom.xml                        |  4 +-
 .../curator/x/discovery/DownInstancePolicy.java    |  2 +-
 .../apache/curator/x/discovery/InstanceFilter.java |  3 +-
 .../apache/curator/x/discovery/LocalIpFilter.java  |  3 +-
 .../curator/x/discovery/ProviderStrategy.java      |  3 +-
 .../apache/curator/x/discovery/ServiceCache.java   |  3 +-
 .../curator/x/discovery/ServiceCacheBuilder.java   |  3 +-
 .../curator/x/discovery/ServiceDiscovery.java      |  3 +-
 .../x/discovery/ServiceDiscoveryBuilder.java       |  2 +-
 .../curator/x/discovery/ServiceInstance.java       |  3 +-
 .../x/discovery/ServiceInstanceBuilder.java        |  3 +-
 .../curator/x/discovery/ServiceProvider.java       |  2 +-
 .../x/discovery/ServiceProviderBuilder.java        |  3 +-
 .../apache/curator/x/discovery/ServiceType.java    |  3 +-
 .../org/apache/curator/x/discovery/UriSpec.java    |  3 +-
 .../x/discovery/details/DownInstanceManager.java   |  3 +-
 .../details/FilteredInstanceProvider.java          |  3 +-
 .../x/discovery/details/InstanceProvider.java      |  3 +-
 .../x/discovery/details/InstanceSerializer.java    |  3 +-
 .../discovery/details/JsonInstanceSerializer.java  |  2 +-
 .../apache/curator/x/discovery/details/Latch.java  |  3 +-
 .../x/discovery/details/OldServiceInstance.java    |  2 +-
 .../discovery/details/ServiceCacheBuilderImpl.java |  3 +-
 .../x/discovery/details/ServiceCacheImpl.java      |  2 +-
 .../x/discovery/details/ServiceCacheListener.java  |  3 +-
 .../x/discovery/details/ServiceDiscoveryImpl.java  |  2 +-
 .../details/ServiceProviderBuilderImpl.java        |  3 +-
 .../x/discovery/details/ServiceProviderImpl.java   |  3 +-
 .../x/discovery/strategies/RandomStrategy.java     |  3 +-
 .../x/discovery/strategies/RoundRobinStrategy.java |  3 +-
 .../x/discovery/strategies/StickyStrategy.java     |  3 +-
 .../x/discovery/ServiceCacheLeakTester.java        |  3 +-
 .../x/discovery/TestJsonInstanceSerializer.java    |  3 +-
 .../curator/x/discovery/TestLocalIpFilter.java     |  3 +-
 .../curator/x/discovery/TestServiceCache.java      |  2 +-
 .../apache/curator/x/discovery/TestStrategies.java |  3 +-
 .../apache/curator/x/discovery/TestUriSpec.java    |  3 +-
 .../discovery/details/TestDownInstanceManager.java |  3 +-
 .../TestJsonInstanceSerializerCompatibility.java   |  2 +-
 .../discovery/details/TestNewServiceInstance.java  |  3 +-
 .../x/discovery/details/TestServiceCacheRace.java  |  3 +-
 .../x/discovery/details/TestServiceDiscovery.java  |  2 +-
 .../details/TestServiceDiscoveryBuilder.java       |  3 +-
 .../x/discovery/details/TestServiceProvider.java   |  3 +-
 .../x/discovery/details/TestWatchedInstances.java  |  3 +-
 .../src/test/resources/log4j.properties            |  2 -
 .../test/resources/schema.yaml => licenserc.toml   | 20 +++----
 merge-pr.py                                        | 29 +++++-----
 pom.xml                                            | 63 +++-------------------
 719 files changed, 1473 insertions(+), 938 deletions(-)
 copy curator-framework/src/test/resources/log4j.properties => .asf.yaml (56%)
 copy curator-framework/src/test/resources/schema.yaml => licenserc.toml (78%)


[curator] 01/02: CURATOR-661: Use license header checker and add required status

Posted by ti...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

tison pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/curator.git

commit 89df142a0509c5371f49ba80fd55157483daf75b
Author: tison <wa...@gmail.com>
AuthorDate: Mon Mar 13 13:52:01 2023 +0800

    CURATOR-661: Use license header checker and add required status
    
    Signed-off-by: tison <wa...@gmail.com>
---
 .asf.yaml                | 46 +++++++++++++++++++++++++++++++++++++++
 .github/workflows/ci.yml | 39 +++++++++++++++++++--------------
 licenserc.toml           | 25 +++++++++++++++++++++
 pom.xml                  | 56 ++----------------------------------------------
 4 files changed, 96 insertions(+), 70 deletions(-)

diff --git a/.asf.yaml b/.asf.yaml
new file mode 100644
index 00000000..54e12d52
--- /dev/null
+++ b/.asf.yaml
@@ -0,0 +1,46 @@
+# Licensed 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 licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+github:
+  description: "Apache Curator"
+  homepage: https://curator.apache.org/
+  labels:
+    - java
+    - database
+    - curator
+    - zookeeper
+    - consensus
+  features:
+    wiki: false
+    issues: false
+    projects: false
+  enabled_merge_buttons:
+    squash:  true
+    merge:   false
+    rebase:  true
+  protected_branches:
+    master:
+      required_status_checks:
+        strict: false
+        contexts:
+          - Required
+      required_signatures: false
+
+notifications:
+  commits:      commits@curator.apache.org
+  pullrequests: commits@curator.apache.org
+  jira_options: link label
diff --git a/.github/workflows/ci.yml b/.github/workflows/ci.yml
index e131fed8..06f80891 100644
--- a/.github/workflows/ci.yml
+++ b/.github/workflows/ci.yml
@@ -30,28 +30,17 @@ jobs:
     name: Check
     runs-on: ubuntu-latest
     steps:
-      - name: Checkout
-        uses: actions/checkout@v3
-
-      - name: Set up JDK 11
-        uses: actions/setup-java@v3
-        with:
-          java-version: 11
-          distribution: 'temurin'
-
-      - name: RAT check
-        run: ./mvnw apache-rat:check
+      - uses: actions/checkout@v3
+      - name: Check license header
+        run: docker run --rm -v $(pwd):/github/workspace -u $(id -u):$(id -g) ghcr.io/korandoru/hawkeye-native:v1 check
 
-  test:
+  unittest:
     name: Unit tests
     runs-on: ubuntu-latest
     timeout-minutes: 120
     strategy:
       matrix:
-        java:
-        - '8'
-        - '11'
-
+        java: [8, 11]
     steps:
       - uses: actions/checkout@v3
 
@@ -74,3 +63,21 @@ jobs:
 
       - name: Test with ${{ matrix.java }}
         run: ./mvnw verify
+
+  required:
+    name: Required
+    runs-on: ubuntu-latest
+    if: ${{ always() }}
+    needs:
+      - check
+      - unittest
+    steps:
+      - name: Guardian
+        run: |
+          if [[ ! ( \
+                 "${{ needs.check.result }}" == "success" \
+              && "${{ needs.unittest.result }}" == "success" \
+              ) ]]; then
+            echo "Required jobs haven't been completed successfully."
+            exit -1
+          fi
diff --git a/licenserc.toml b/licenserc.toml
new file mode 100644
index 00000000..09593513
--- /dev/null
+++ b/licenserc.toml
@@ -0,0 +1,25 @@
+# Licensed 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 licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+headerPath = "Apache-2.0-ASF.txt"
+
+excludes = [
+    "DEPENDENCIES",
+    "doap.rdf",
+    "**/NOTICE",
+    "**/*.confluence",
+]
diff --git a/pom.xml b/pom.xml
index ab8a5891..01b3708d 100644
--- a/pom.xml
+++ b/pom.xml
@@ -73,10 +73,10 @@
         <maven-bundle-plugin-version>5.1.4</maven-bundle-plugin-version>
         <maven-compiler-plugin-version>3.10.0</maven-compiler-plugin-version>
         <maven-dependency-plugin-version>3.2.0</maven-dependency-plugin-version>
+        <maven-project-info-reports-plugin-version>3.0.0</maven-project-info-reports-plugin-version>
         <maven-javadoc-plugin-version>3.3.2</maven-javadoc-plugin-version>
         <maven-surefire-plugin-version>3.0.0-M5</maven-surefire-plugin-version>
         <doxia-module-confluence-version>1.11.1</doxia-module-confluence-version>
-        <directory-maven-plugin-version>1.0</directory-maven-plugin-version>
         <javassist-version>3.24.1-GA</javassist-version>
         <commons-math-version>2.2</commons-math-version>
         <jackson-mapper-asl-version>1.9.13</jackson-mapper-asl-version>
@@ -662,6 +662,7 @@
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-project-info-reports-plugin</artifactId>
+                <version>${maven-project-info-reports-plugin-version}</version>
             </plugin>
 
             <plugin>
@@ -697,12 +698,6 @@
                     <version>${maven-bundle-plugin-version}</version>
                 </plugin>
 
-                <plugin>
-                    <groupId>org.commonjava.maven.plugins</groupId>
-                    <artifactId>directory-maven-plugin</artifactId>
-                    <version>${directory-maven-plugin-version}</version>
-                </plugin>
-
                 <plugin>
                     <groupId>org.apache.maven.plugins</groupId>
                     <artifactId>maven-release-plugin</artifactId>
@@ -855,24 +850,6 @@
                 </executions>
             </plugin>
 
-            <!-- Directory plugin to find parent root directory absolute path -->
-            <plugin>
-                <groupId>org.commonjava.maven.plugins</groupId>
-                <artifactId>directory-maven-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>directories</id>
-                        <goals>
-                            <goal>highest-basedir</goal>
-                        </goals>
-                        <phase>validate</phase>
-                        <configuration>
-                            <property>main.basedir</property>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-release-plugin</artifactId>
@@ -882,35 +859,6 @@
                 </configuration>
             </plugin>
 
-            <plugin>
-                <groupId>org.apache.rat</groupId>
-                <artifactId>apache-rat-plugin</artifactId>
-                <configuration>
-                    <numUnapprovedLicenses>0</numUnapprovedLicenses>
-                    <excludeSubProjects>false</excludeSubProjects>
-                    <excludes>
-                        <exclude>**/*.confluence</exclude>
-                        <exclude>**/*.iml</exclude>
-                        <exclude>**/*.rdf</exclude>
-                        <exclude>**/help.txt</exclude>
-                        <exclude>**/.gitignore</exclude>
-                        <exclude>**/*.thrift</exclude>
-                        <exclude>**/*.json</exclude>
-                        <exclude>**/.idea/**</exclude>
-                        <exclude>**/DISCLAIMER</exclude>
-                        <exclude>**/DEPENDENCIES</exclude>
-                        <exclude>**/KEYS</exclude>
-                        <exclude>**/LICENSE</exclude>
-                        <exclude>**/NOTICE</exclude>
-                        <exclude>**/README</exclude>
-                        <exclude>**/CHANGES</exclude>
-                        <exclude>**/RELEASE-NOTES</exclude>
-                        <exclude>**/target/**</exclude>
-                        <exclude>**/generated/**</exclude>
-                    </excludes>
-                </configuration>
-            </plugin>
-
             <plugin>
                 <groupId>org.codehaus.mojo</groupId>
                 <artifactId>clirr-maven-plugin</artifactId>


[curator] 02/02: CURATOR-661: Apply license header reformat

Posted by ti...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

tison pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/curator.git

commit 79edb0e20891951b7e4456d2b68c6ce64938f4e8
Author: tison <wa...@gmail.com>
AuthorDate: Mon Mar 13 13:56:39 2023 +0800

    CURATOR-661: Apply license header reformat
    
    Signed-off-by: tison <wa...@gmail.com>
---
 curator-client/pom.xml                             |  7 ++--
 .../java/org/apache/curator/ConnectionState.java   |  3 +-
 .../curator/CuratorConnectionLossException.java    |  3 +-
 .../org/apache/curator/CuratorZookeeperClient.java |  2 +-
 .../main/java/org/apache/curator/HandleHolder.java |  3 +-
 .../src/main/java/org/apache/curator/Helper.java   |  3 +-
 .../main/java/org/apache/curator/RetryLoop.java    |  3 +-
 .../java/org/apache/curator/RetryLoopImpl.java     |  2 +-
 .../main/java/org/apache/curator/RetryPolicy.java  |  3 +-
 .../main/java/org/apache/curator/RetrySleeper.java |  3 +-
 .../org/apache/curator/SessionFailRetryLoop.java   |  3 +-
 .../apache/curator/SessionFailedRetryPolicy.java   |  3 +-
 .../main/java/org/apache/curator/TimeTrace.java    |  3 +-
 .../curator/connection/ThreadLocalRetryLoop.java   |  3 +-
 .../curator/drivers/AdvancedTracerDriver.java      |  3 +-
 .../org/apache/curator/drivers/EventTrace.java     |  3 +-
 .../org/apache/curator/drivers/OperationTrace.java |  3 +-
 .../org/apache/curator/drivers/TracerDriver.java   |  3 +-
 .../apache/curator/ensemble/EnsembleProvider.java  |  3 +-
 .../ensemble/fixed/FixedEnsembleProvider.java      |  3 +-
 .../retry/BoundedExponentialBackoffRetry.java      |  3 +-
 .../curator/retry/ExponentialBackoffRetry.java     |  3 +-
 .../org/apache/curator/retry/RetryForever.java     |  3 +-
 .../java/org/apache/curator/retry/RetryNTimes.java |  3 +-
 .../org/apache/curator/retry/RetryOneTime.java     |  3 +-
 .../apache/curator/retry/RetryUntilElapsed.java    |  3 +-
 .../org/apache/curator/retry/SleepingRetry.java    |  3 +-
 .../curator/utils/CloseableExecutorService.java    |  2 +-
 .../utils/CloseableScheduledExecutorService.java   |  2 +-
 .../org/apache/curator/utils/CloseableUtils.java   |  2 +-
 .../org/apache/curator/utils/Compatibility.java    |  2 +-
 .../utils/ConfigurableZookeeperFactory.java        |  2 +-
 .../java/org/apache/curator/utils/DebugUtils.java  |  2 +-
 .../apache/curator/utils/DefaultTracerDriver.java  |  3 +-
 .../curator/utils/DefaultZookeeperFactory.java     |  3 +-
 .../java/org/apache/curator/utils/EnsurePath.java  |  2 +-
 .../apache/curator/utils/ExceptionAccumulator.java |  3 +-
 .../apache/curator/utils/InternalACLProvider.java  |  2 +-
 .../curator/utils/NonAdminZookeeperFactory.java    |  3 +-
 .../java/org/apache/curator/utils/PathUtils.java   |  3 +-
 .../java/org/apache/curator/utils/ThreadUtils.java |  3 +-
 .../java/org/apache/curator/utils/ZKPaths.java     |  2 +-
 .../org/apache/curator/utils/ZookeeperFactory.java |  3 +-
 .../test/java/org/apache/curator/BasicTests.java   |  3 +-
 .../java/org/apache/curator/TestEnsurePath.java    |  3 +-
 .../src/test/java/org/apache/curator/TestIs37.java |  3 +-
 .../java/org/apache/curator/TestRetryLoop.java     |  3 +-
 .../apache/curator/TestSessionFailRetryLoop.java   |  3 +-
 .../utils/TestCloseableExecutorService.java        |  2 +-
 .../TestCloseableScheduledExecutorService.java     |  3 +-
 .../java/org/apache/curator/utils/TestZKPaths.java |  2 +-
 curator-client/src/test/resources/log4j.properties |  2 --
 curator-examples/pom.xml                           |  4 ++-
 .../src/main/java/async/AsyncExamples.java         |  3 +-
 .../src/main/java/cache/CuratorCacheExample.java   |  2 +-
 .../src/main/java/cache/PathCacheExample.java      |  3 +-
 .../src/main/java/cache/TreeCacheExample.java      |  3 +-
 .../src/main/java/discovery/DiscoveryExample.java  |  3 +-
 .../src/main/java/discovery/ExampleServer.java     |  3 +-
 .../src/main/java/discovery/InstanceDetails.java   |  3 +-
 .../main/java/framework/CreateClientExamples.java  |  3 +-
 .../src/main/java/framework/CrudExamples.java      |  3 +-
 .../main/java/framework/TransactionExamples.java   |  3 +-
 .../src/main/java/leader/ExampleClient.java        |  3 +-
 .../main/java/leader/LeaderSelectorExample.java    |  3 +-
 .../main/java/locking/ExampleClientThatLocks.java  |  3 +-
 .../src/main/java/locking/FakeLimitedResource.java |  3 +-
 .../src/main/java/locking/LockingExample.java      |  3 +-
 .../src/main/java/modeled/ContainerType.java       |  3 +-
 .../main/java/modeled/ModeledCuratorExamples.java  |  3 +-
 .../java/modeled/ModeledCuratorExamplesAlt.java    |  3 +-
 .../src/main/java/modeled/PersonId.java            |  3 +-
 .../src/main/java/modeled/PersonModel.java         |  3 +-
 .../src/main/java/modeled/PersonModelSpec.java     |  3 +-
 curator-examples/src/main/java/pubsub/Clients.java |  3 +-
 .../src/main/java/pubsub/Publisher.java            |  3 +-
 .../src/main/java/pubsub/SubPubTest.java           |  3 +-
 .../src/main/java/pubsub/Subscriber.java           |  3 +-
 .../java/pubsub/messages/LocationAvailable.java    |  3 +-
 .../src/main/java/pubsub/messages/UserCreated.java |  3 +-
 .../src/main/java/pubsub/models/Group.java         |  3 +-
 .../src/main/java/pubsub/models/Instance.java      |  3 +-
 .../src/main/java/pubsub/models/InstanceType.java  |  3 +-
 .../src/main/java/pubsub/models/Message.java       |  3 +-
 .../src/main/java/pubsub/models/Priority.java      |  3 +-
 .../src/main/resources/log4j.properties            |  2 --
 curator-framework/pom.xml                          |  4 ++-
 .../org/apache/curator/framework/AuthInfo.java     |  2 +-
 .../apache/curator/framework/CuratorFramework.java |  2 +-
 .../curator/framework/CuratorFrameworkFactory.java |  2 +-
 .../curator/framework/CuratorTempFramework.java    |  3 +-
 .../apache/curator/framework/EnsureContainers.java |  3 +-
 .../framework/WatcherRemoveCuratorFramework.java   |  3 +-
 .../api/ACLBackgroundPathAndBytesable.java         |  3 +-
 .../ACLCreateModeBackgroundPathAndBytesable.java   |  3 +-
 .../api/ACLCreateModePathAndBytesable.java         |  3 +-
 ...CLCreateModeStatBackgroundPathAndBytesable.java |  3 +-
 .../curator/framework/api/ACLPathAndBytesable.java |  3 +-
 .../apache/curator/framework/api/ACLProvider.java  |  3 +-
 .../org/apache/curator/framework/api/ACLable.java  |  3 +-
 .../framework/api/ACLableExistBuilderMain.java     |  2 +-
 .../framework/api/AddStatConfigEnsembleable.java   |  2 +-
 .../curator/framework/api/AddWatchBuilder.java     |  3 +-
 .../curator/framework/api/AddWatchBuilder2.java    |  2 +-
 .../org/apache/curator/framework/api/Addable.java  |  2 +-
 .../curator/framework/api/AsyncReconfigurable.java |  3 +-
 .../curator/framework/api/BackgroundCallback.java  |  3 +-
 .../framework/api/BackgroundEnsembleable.java      |  3 +-
 .../framework/api/BackgroundPathAndBytesable.java  |  3 +-
 .../curator/framework/api/BackgroundPathable.java  |  3 +-
 .../api/BackgroundPathableQuietlyable.java         |  3 +-
 .../framework/api/BackgroundVersionable.java       |  3 +-
 .../curator/framework/api/Backgroundable.java      |  3 +-
 .../curator/framework/api/ChildrenDeletable.java   |  3 +-
 .../apache/curator/framework/api/Compressible.java |  3 +-
 .../curator/framework/api/CompressionProvider.java |  3 +-
 .../framework/api/ConfigureEnsembleable.java       |  2 +-
 .../framework/api/CreateBackgroundModeACLable.java |  3 +-
 .../api/CreateBackgroundModeStatACLable.java       |  3 +-
 .../curator/framework/api/CreateBuilder.java       |  3 +-
 .../curator/framework/api/CreateBuilder2.java      |  3 +-
 .../curator/framework/api/CreateBuilderMain.java   |  3 +-
 .../curator/framework/api/CreateModable.java       |  3 +-
 ...CreateProtectACLCreateModePathAndBytesable.java |  3 +-
 .../apache/curator/framework/api/CuratorEvent.java |  3 +-
 .../curator/framework/api/CuratorEventType.java    |  3 +-
 .../curator/framework/api/CuratorListener.java     |  3 +-
 .../curator/framework/api/CuratorWatcher.java      |  3 +-
 .../curator/framework/api/DataCallbackable.java    |  3 +-
 .../curator/framework/api/Decompressible.java      |  3 +-
 .../curator/framework/api/DeleteBuilder.java       |  3 +-
 .../curator/framework/api/DeleteBuilderMain.java   |  3 +-
 .../apache/curator/framework/api/Ensembleable.java |  3 +-
 .../framework/api/ErrorListenerEnsembleable.java   |  3 +-
 .../api/ErrorListenerMultiTransactionMain.java     |  3 +-
 .../api/ErrorListenerPathAndBytesable.java         |  3 +-
 .../framework/api/ErrorListenerPathable.java       |  3 +-
 .../api/ErrorListenerReconfigBuilderMain.java      |  3 +-
 .../curator/framework/api/ExistsBuilder.java       |  2 +-
 .../curator/framework/api/ExistsBuilderMain.java   |  3 +-
 .../curator/framework/api/GetACLBuilder.java       |  3 +-
 .../curator/framework/api/GetChildrenBuilder.java  |  3 +-
 .../curator/framework/api/GetConfigBuilder.java    |  2 +-
 .../curator/framework/api/GetDataBuilder.java      |  3 +-
 .../api/GetDataWatchBackgroundStatable.java        |  3 +-
 .../curator/framework/api/Guaranteeable.java       |  3 +-
 .../framework/api/GuaranteeableDeletable.java      |  3 +-
 .../curator/framework/api/Idempotentable.java      |  3 +-
 .../framework/api/JoinStatConfigEnsembleable.java  |  2 +-
 .../org/apache/curator/framework/api/Joinable.java |  2 +-
 .../framework/api/LeaveStatConfigEnsembleable.java |  2 +-
 .../apache/curator/framework/api/Leaveable.java    |  2 +-
 .../apache/curator/framework/api/Membersable.java  |  2 +-
 .../curator/framework/api/ParentACLable.java       |  3 +-
 .../curator/framework/api/PathAndBytesable.java    |  3 +-
 .../org/apache/curator/framework/api/Pathable.java |  3 +-
 .../api/ProtectACLCreateModePathAndBytesable.java  |  3 +-
 .../ProtectACLCreateModeStatPathAndBytesable.java  |  3 +-
 .../org/apache/curator/framework/api/Quietly.java  |  3 +-
 .../curator/framework/api/ReconfigBuilder.java     |  2 +-
 .../curator/framework/api/ReconfigBuilderMain.java |  2 +-
 .../framework/api/RemoveWatchesBuilder.java        | 37 +++++++++++-----------
 .../curator/framework/api/RemoveWatchesLocal.java  | 37 +++++++++++-----------
 .../curator/framework/api/RemoveWatchesType.java   | 37 +++++++++++-----------
 .../curator/framework/api/SetACLBuilder.java       |  3 +-
 .../api/SetDataBackgroundVersionable.java          |  3 +-
 .../curator/framework/api/SetDataBuilder.java      |  3 +-
 .../framework/api/StatConfigureEnsembleable.java   |  2 +-
 .../apache/curator/framework/api/StatPathable.java |  3 +-
 .../org/apache/curator/framework/api/Statable.java |  3 +-
 .../apache/curator/framework/api/SyncBuilder.java  |  3 +-
 .../curator/framework/api/TempGetDataBuilder.java  |  3 +-
 .../framework/api/UnhandledErrorListener.java      |  3 +-
 .../framework/api/VersionPathAndBytesable.java     |  3 +-
 .../apache/curator/framework/api/Versionable.java  |  3 +-
 .../framework/api/WatchBackgroundEnsembleable.java |  3 +-
 .../curator/framework/api/WatchPathable.java       |  3 +-
 .../apache/curator/framework/api/Watchable.java    |  3 +-
 .../curator/framework/api/WatchableBase.java       |  3 +-
 .../curator/framework/api/WatchesBuilder.java      |  2 +-
 .../api/transaction/CuratorMultiTransaction.java   |  3 +-
 .../transaction/CuratorMultiTransactionMain.java   |  3 +-
 .../framework/api/transaction/CuratorOp.java       |  3 +-
 .../api/transaction/CuratorTransaction.java        |  3 +-
 .../api/transaction/CuratorTransactionBridge.java  |  3 +-
 .../api/transaction/CuratorTransactionFinal.java   |  3 +-
 .../api/transaction/CuratorTransactionResult.java  |  2 +-
 .../framework/api/transaction/OperationType.java   |  3 +-
 .../api/transaction/TransactionCheckBuilder.java   |  3 +-
 .../api/transaction/TransactionCreateBuilder.java  |  3 +-
 .../api/transaction/TransactionCreateBuilder2.java |  3 +-
 .../api/transaction/TransactionDeleteBuilder.java  |  3 +-
 .../framework/api/transaction/TransactionOp.java   |  3 +-
 .../api/transaction/TransactionSetDataBuilder.java |  3 +-
 .../framework/api/transaction/TypeAndPath.java     |  3 +-
 .../org/apache/curator/framework/imps/ACLing.java  |  3 +-
 .../framework/imps/AddWatchBuilderImpl.java        |  2 +-
 .../framework/imps/BackgroundOperation.java        |  3 +-
 .../curator/framework/imps/BackgroundSyncImpl.java |  3 +-
 .../curator/framework/imps/Backgrounding.java      |  2 +-
 .../curator/framework/imps/CreateBuilderImpl.java  |  2 +-
 .../curator/framework/imps/CuratorEventImpl.java   |  2 +-
 .../framework/imps/CuratorFrameworkImpl.java       |  2 +-
 .../framework/imps/CuratorFrameworkState.java      |  3 +-
 .../imps/CuratorMultiTransactionImpl.java          |  2 +-
 .../imps/CuratorMultiTransactionRecord.java        |  2 +-
 .../framework/imps/CuratorTempFrameworkImpl.java   |  3 +-
 .../framework/imps/CuratorTransactionImpl.java     |  2 +-
 .../curator/framework/imps/DefaultACLProvider.java |  3 +-
 .../curator/framework/imps/DeleteBuilderImpl.java  |  3 +-
 .../curator/framework/imps/EnsembleTracker.java    |  2 +-
 .../curator/framework/imps/ExistsBuilderImpl.java  |  3 +-
 .../framework/imps/ExtractingCuratorOp.java        |  3 +-
 .../framework/imps/FailedDeleteManager.java        |  3 +-
 .../framework/imps/FailedOperationManager.java     |  3 +-
 .../framework/imps/FailedRemoveWatchManager.java   |  3 +-
 .../FindAndDeleteProtectedNodeInBackground.java    |  3 +-
 .../curator/framework/imps/GetACLBuilderImpl.java  |  3 +-
 .../framework/imps/GetChildrenBuilderImpl.java     |  3 +-
 .../framework/imps/GetConfigBuilderImpl.java       |  2 +-
 .../curator/framework/imps/GetDataBuilderImpl.java |  3 +-
 .../framework/imps/GzipCompressionProvider.java    |  3 +-
 .../curator/framework/imps/IdempotentUtils.java    |  3 +-
 .../framework/imps/InternalConnectionHandler.java  |  3 +-
 .../curator/framework/imps/NamespaceFacade.java    |  3 +-
 .../framework/imps/NamespaceFacadeCache.java       |  3 +-
 .../curator/framework/imps/NamespaceImpl.java      |  3 +-
 .../framework/imps/NamespaceWatchedEvent.java      |  3 +-
 .../curator/framework/imps/NamespaceWatcher.java   |  3 +-
 .../curator/framework/imps/OperationAndData.java   |  2 +-
 .../curator/framework/imps/PathAndBytes.java       |  3 +-
 .../curator/framework/imps/ProtectedMode.java      |  2 +-
 .../curator/framework/imps/ProtectedUtils.java     |  3 +-
 .../framework/imps/ReconfigBuilderImpl.java        |  2 +-
 .../framework/imps/RemoveWatchesBuilderImpl.java   | 37 +++++++++++-----------
 .../curator/framework/imps/SetACLBuilderImpl.java  |  3 +-
 .../curator/framework/imps/SetDataBuilderImpl.java |  3 +-
 .../imps/StandardInternalConnectionHandler.java    |  3 +-
 .../curator/framework/imps/SyncBuilderImpl.java    |  3 +-
 .../framework/imps/TempGetDataBuilderImpl.java     |  3 +-
 .../curator/framework/imps/TransactionOpImpl.java  |  3 +-
 .../framework/imps/WatcherRemovalFacade.java       |  2 +-
 .../framework/imps/WatcherRemovalManager.java      |  3 +-
 .../curator/framework/imps/WatchesBuilderImpl.java |  2 +-
 .../apache/curator/framework/imps/Watching.java    |  2 +-
 .../curator/framework/listen/Listenable.java       |  3 +-
 .../curator/framework/listen/ListenerEntry.java    |  3 +-
 .../curator/framework/listen/ListenerManager.java  |  3 +-
 .../framework/listen/MappingListenerManager.java   |  3 +-
 .../framework/listen/StandardListenerManager.java  |  3 +-
 .../framework/listen/UnaryListenerManager.java     |  3 +-
 .../framework/schema/DefaultSchemaValidator.java   |  3 +-
 .../apache/curator/framework/schema/Schema.java    |  3 +-
 .../curator/framework/schema/SchemaBuilder.java    |  3 +-
 .../apache/curator/framework/schema/SchemaSet.java |  3 +-
 .../curator/framework/schema/SchemaSetLoader.java  |  3 +-
 .../curator/framework/schema/SchemaValidator.java  |  3 +-
 .../curator/framework/schema/SchemaViolation.java  |  3 +-
 .../curator/framework/state/CircuitBreaker.java    |  3 +-
 .../CircuitBreakingConnectionStateListener.java    |  3 +-
 .../framework/state/CircuitBreakingManager.java    |  3 +-
 .../curator/framework/state/ConnectionState.java   |  3 +-
 .../state/ConnectionStateErrorPolicy.java          |  3 +-
 .../framework/state/ConnectionStateListener.java   |  3 +-
 .../ConnectionStateListenerManagerFactory.java     |  3 +-
 .../framework/state/ConnectionStateManager.java    |  2 +-
 .../state/SessionConnectionStateErrorPolicy.java   |  3 +-
 .../state/StandardConnectionStateErrorPolicy.java  |  3 +-
 .../framework/ensemble/TestEnsembleProvider.java   |  3 +-
 .../framework/imps/TestBlockUntilConnected.java    |  2 +-
 .../curator/framework/imps/TestCleanState.java     |  3 +-
 .../curator/framework/imps/TestCompression.java    |  3 +-
 .../imps/TestCompressionInTransactionNew.java      |  3 +-
 .../imps/TestCompressionInTransactionOld.java      |  3 +-
 .../apache/curator/framework/imps/TestCreate.java  |  3 +-
 .../framework/imps/TestCreateReturningStat.java    | 37 +++++++++++-----------
 .../apache/curator/framework/imps/TestDelete.java  |  3 +-
 .../imps/TestEnabledSessionExpiredState.java       |  3 +-
 .../framework/imps/TestEnsureContainers.java       |  3 +-
 .../curator/framework/imps/TestExistsBuilder.java  |  3 +-
 .../framework/imps/TestFailedDeleteManager.java    |  3 +-
 .../curator/framework/imps/TestFramework.java      |  3 +-
 .../framework/imps/TestFrameworkBackground.java    |  2 +-
 .../curator/framework/imps/TestFrameworkEdges.java |  2 +-
 .../imps/TestGzipCompressionProvider.java          |  3 +-
 .../curator/framework/imps/TestMultiClient.java    |  3 +-
 .../framework/imps/TestNamespaceFacade.java        |  3 +-
 .../curator/framework/imps/TestNeverConnected.java |  2 +-
 .../curator/framework/imps/TestReadOnly.java       |  2 +-
 .../framework/imps/TestReconfiguration.java        |  2 +-
 .../apache/curator/framework/imps/TestSetData.java |  3 +-
 .../curator/framework/imps/TestTempFramework.java  |  3 +-
 .../framework/imps/TestTransactionsNew.java        |  2 +-
 .../framework/imps/TestTransactionsOld.java        |  3 +-
 .../curator/framework/imps/TestTtlNodes.java       |  3 +-
 .../framework/imps/TestWatcherIdentity.java        |  3 +-
 .../framework/imps/TestWatcherRemovalManager.java  |  3 +-
 .../curator/framework/imps/TestWatchesBuilder.java | 37 +++++++++++-----------
 .../curator/framework/imps/TestWithCluster.java    |  3 +-
 .../curator/framework/schema/TestSchema.java       |  3 +-
 .../framework/state/TestCircuitBreaker.java        |  3 +-
 ...TestCircuitBreakingConnectionStateListener.java |  3 +-
 .../state/TestConnectionStateManager.java          |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-recipes/pom.xml                            |  4 ++-
 .../recipes/AfterConnectionEstablished.java        |  2 +-
 .../framework/recipes/atomic/AtomicStats.java      |  3 +-
 .../framework/recipes/atomic/AtomicValue.java      |  3 +-
 .../recipes/atomic/CachedAtomicInteger.java        |  3 +-
 .../framework/recipes/atomic/CachedAtomicLong.java |  3 +-
 .../recipes/atomic/DistributedAtomicInteger.java   |  3 +-
 .../recipes/atomic/DistributedAtomicLong.java      |  3 +-
 .../recipes/atomic/DistributedAtomicNumber.java    |  2 +-
 .../recipes/atomic/DistributedAtomicValue.java     |  3 +-
 .../framework/recipes/atomic/MakeValue.java        |  3 +-
 .../recipes/atomic/MutableAtomicValue.java         |  3 +-
 .../framework/recipes/atomic/PromotedToLock.java   |  3 +-
 .../recipes/barriers/DistributedBarrier.java       |  3 +-
 .../recipes/barriers/DistributedDoubleBarrier.java |  3 +-
 .../curator/framework/recipes/cache/ChildData.java |  3 +-
 .../cache/CompatibleCuratorCacheBridge.java        |  3 +-
 .../framework/recipes/cache/CuratorCache.java      |  2 +-
 .../recipes/cache/CuratorCacheAccessor.java        |  2 +-
 .../recipes/cache/CuratorCacheBridge.java          |  3 +-
 .../recipes/cache/CuratorCacheBridgeBuilder.java   |  2 +-
 .../cache/CuratorCacheBridgeBuilderImpl.java       |  2 +-
 .../recipes/cache/CuratorCacheBuilder.java         |  2 +-
 .../recipes/cache/CuratorCacheBuilderImpl.java     |  2 +-
 .../framework/recipes/cache/CuratorCacheImpl.java  |  3 +-
 .../recipes/cache/CuratorCacheListener.java        |  2 +-
 .../recipes/cache/CuratorCacheListenerBuilder.java |  2 +-
 .../cache/CuratorCacheListenerBuilderImpl.java     |  2 +-
 .../recipes/cache/CuratorCacheStorage.java         |  3 +-
 .../recipes/cache/DefaultTreeCacheSelector.java    |  3 +-
 .../framework/recipes/cache/EventOperation.java    |  3 +-
 .../framework/recipes/cache/GetDataOperation.java  |  3 +-
 .../curator/framework/recipes/cache/NodeCache.java |  3 +-
 .../framework/recipes/cache/NodeCacheListener.java |  3 +-
 .../recipes/cache/NodeCacheListenerWrapper.java    |  2 +-
 .../curator/framework/recipes/cache/Operation.java |  3 +-
 .../framework/recipes/cache/PathChildrenCache.java |  2 +-
 .../recipes/cache/PathChildrenCacheEvent.java      |  3 +-
 .../recipes/cache/PathChildrenCacheListener.java   |  3 +-
 .../cache/PathChildrenCacheListenerWrapper.java    |  2 +-
 .../recipes/cache/PathChildrenCacheMode.java       |  3 +-
 .../framework/recipes/cache/RefreshOperation.java  |  3 +-
 .../recipes/cache/StandardCuratorCacheStorage.java |  2 +-
 .../curator/framework/recipes/cache/TreeCache.java |  2 +-
 .../framework/recipes/cache/TreeCacheEvent.java    |  2 +-
 .../framework/recipes/cache/TreeCacheIterator.java |  3 +-
 .../framework/recipes/cache/TreeCacheListener.java |  2 +-
 .../recipes/cache/TreeCacheListenerWrapper.java    |  2 +-
 .../framework/recipes/cache/TreeCacheSelector.java |  3 +-
 .../recipes/leader/CancelLeadershipException.java  |  3 +-
 .../framework/recipes/leader/LeaderLatch.java      |  2 +-
 .../recipes/leader/LeaderLatchListener.java        |  3 +-
 .../framework/recipes/leader/LeaderSelector.java   |  2 +-
 .../recipes/leader/LeaderSelectorListener.java     |  3 +-
 .../leader/LeaderSelectorListenerAdapter.java      |  3 +-
 .../framework/recipes/leader/Participant.java      |  3 +-
 .../framework/recipes/locks/InterProcessLock.java  |  3 +-
 .../recipes/locks/InterProcessMultiLock.java       |  3 +-
 .../framework/recipes/locks/InterProcessMutex.java |  2 +-
 .../recipes/locks/InterProcessReadWriteLock.java   |  3 +-
 .../recipes/locks/InterProcessSemaphore.java       |  3 +-
 .../recipes/locks/InterProcessSemaphoreMutex.java  |  3 +-
 .../recipes/locks/InterProcessSemaphoreV2.java     |  2 +-
 .../curator/framework/recipes/locks/Lease.java     |  3 +-
 .../framework/recipes/locks/LockInternals.java     |  3 +-
 .../recipes/locks/LockInternalsDriver.java         |  3 +-
 .../recipes/locks/LockInternalsSorter.java         |  3 +-
 .../curator/framework/recipes/locks/Locker.java    |  3 +-
 .../framework/recipes/locks/PredicateResults.java  |  3 +-
 .../curator/framework/recipes/locks/Revocable.java |  3 +-
 .../recipes/locks/RevocationListener.java          |  3 +-
 .../framework/recipes/locks/RevocationSpec.java    |  3 +-
 .../curator/framework/recipes/locks/Revoker.java   |  3 +-
 .../recipes/locks/StandardLockInternalsDriver.java |  3 +-
 .../framework/recipes/nodes/GroupMember.java       |  3 +-
 .../recipes/nodes/PersistentEphemeralNode.java     |  2 +-
 .../framework/recipes/nodes/PersistentNode.java    |  2 +-
 .../recipes/nodes/PersistentNodeListener.java      |  2 +-
 .../framework/recipes/nodes/PersistentTtlNode.java |  3 +-
 .../recipes/queue/BlockingQueueConsumer.java       |  3 +-
 .../framework/recipes/queue/ChildrenCache.java     |  3 +-
 .../recipes/queue/DistributedDelayQueue.java       |  3 +-
 .../recipes/queue/DistributedIdQueue.java          |  3 +-
 .../recipes/queue/DistributedPriorityQueue.java    |  3 +-
 .../framework/recipes/queue/DistributedQueue.java  |  3 +-
 .../curator/framework/recipes/queue/ErrorMode.java |  3 +-
 .../framework/recipes/queue/ItemSerializer.java    |  3 +-
 .../curator/framework/recipes/queue/MultiItem.java |  3 +-
 .../framework/recipes/queue/QueueAllocator.java    |  3 +-
 .../curator/framework/recipes/queue/QueueBase.java |  3 +-
 .../framework/recipes/queue/QueueBuilder.java      |  3 +-
 .../framework/recipes/queue/QueueConsumer.java     |  3 +-
 .../framework/recipes/queue/QueuePutListener.java  |  3 +-
 .../framework/recipes/queue/QueueSafety.java       |  3 +-
 .../framework/recipes/queue/QueueSerializer.java   |  3 +-
 .../framework/recipes/queue/QueueSharder.java      |  3 +-
 .../recipes/queue/QueueSharderPolicies.java        |  3 +-
 .../recipes/queue/SimpleDistributedQueue.java      |  3 +-
 .../framework/recipes/shared/SharedCount.java      |  3 +-
 .../recipes/shared/SharedCountListener.java        |  3 +-
 .../recipes/shared/SharedCountReader.java          |  3 +-
 .../framework/recipes/shared/SharedValue.java      |  2 +-
 .../recipes/shared/SharedValueListener.java        |  3 +-
 .../recipes/shared/SharedValueReader.java          |  3 +-
 .../framework/recipes/shared/VersionedValue.java   |  3 +-
 .../framework/recipes/watch/PersistentWatcher.java |  3 +-
 .../connection/TestThreadLocalRetryLoop.java       |  3 +-
 .../framework/client/TestBackgroundStates.java     |  2 +-
 .../TestResetConnectionWithBackgroundFailure.java  |  2 +-
 .../recipes/atomic/TestCachedAtomicCounter.java    |  3 +-
 .../recipes/atomic/TestDistributedAtomicLong.java  |  3 +-
 .../recipes/barriers/TestDistributedBarrier.java   |  3 +-
 .../barriers/TestDistributedDoubleBarrier.java     |  3 +-
 .../framework/recipes/cache/BaseTestTreeCache.java |  2 +-
 .../framework/recipes/cache/TestCuratorCache.java  |  2 +-
 .../recipes/cache/TestCuratorCacheBridge.java      |  2 +-
 .../recipes/cache/TestCuratorCacheConsistency.java |  2 +-
 .../recipes/cache/TestCuratorCacheEdges.java       |  2 +-
 .../cache/TestCuratorCacheEventOrdering.java       |  3 +-
 .../recipes/cache/TestCuratorCacheWrappers.java    |  2 +-
 .../framework/recipes/cache/TestEventOrdering.java |  3 +-
 .../framework/recipes/cache/TestNodeCache.java     |  3 +-
 .../recipes/cache/TestPathChildrenCache.java       |  2 +-
 .../cache/TestPathChildrenCacheEventOrdering.java  |  3 +-
 .../cache/TestPathChildrenCacheInCluster.java      |  3 +-
 .../framework/recipes/cache/TestTreeCache.java     |  2 +-
 .../recipes/cache/TestTreeCacheEventOrdering.java  |  3 +-
 .../cache/TestTreeCacheIteratorAndSize.java        |  3 +-
 .../recipes/cache/TestTreeCacheRandomTree.java     |  2 +-
 .../recipes/cache/TestWrappedNodeCache.java        |  3 +-
 .../recipes/leader/ChaosMonkeyCnxnFactory.java     |  2 +-
 .../framework/recipes/leader/TestLeaderAcls.java   |  2 +-
 .../framework/recipes/leader/TestLeaderLatch.java  |  2 +-
 .../recipes/leader/TestLeaderLatchCluster.java     |  3 +-
 .../recipes/leader/TestLeaderSelector.java         |  2 +-
 .../recipes/leader/TestLeaderSelectorCluster.java  |  3 +-
 .../recipes/leader/TestLeaderSelectorEdges.java    |  2 +-
 .../leader/TestLeaderSelectorParticipants.java     |  3 +-
 .../leader/TestLeaderSelectorWithExecutor.java     |  3 +-
 .../curator/framework/recipes/locks/Counter.java   |  3 +-
 .../framework/recipes/locks/SemaphoreClient.java   |  3 +-
 .../curator/framework/recipes/locks/Stepper.java   |  3 +-
 .../recipes/locks/TestInterProcessMultiMutex.java  |  3 +-
 .../recipes/locks/TestInterProcessMutex.java       |  2 +-
 .../recipes/locks/TestInterProcessMutexBase.java   |  2 +-
 .../locks/TestInterProcessReadWriteLock.java       |  2 +-
 .../recipes/locks/TestInterProcessSemaphore.java   |  2 +-
 .../locks/TestInterProcessSemaphoreCluster.java    |  3 +-
 .../locks/TestInterProcessSemaphoreMutex.java      |  3 +-
 .../framework/recipes/locks/TestLockACLs.java      |  2 +-
 .../locks/TestLockCleanlinessWithFaults.java       |  3 +-
 .../framework/recipes/nodes/TestGroupMember.java   |  3 +-
 .../recipes/nodes/TestPersistentEphemeralNode.java |  3 +-
 .../nodes/TestPersistentEphemeralNodeListener.java |  2 +-
 .../recipes/nodes/TestPersistentNode.java          |  3 +-
 .../recipes/nodes/TestPersistentTtlNode.java       |  3 +-
 .../recipes/queue/QueueItemSerializer.java         |  3 +-
 .../framework/recipes/queue/QueueTestProducer.java |  3 +-
 .../recipes/queue/TestBoundedDistributedQueue.java |  3 +-
 .../recipes/queue/TestDistributedDelayQueue.java   |  3 +-
 .../recipes/queue/TestDistributedIdQueue.java      |  3 +-
 .../queue/TestDistributedPriorityQueue.java        |  3 +-
 .../recipes/queue/TestDistributedQueue.java        |  3 +-
 .../recipes/queue/TestLongNetworkPartition.java    |  3 +-
 .../framework/recipes/queue/TestQueueItem.java     |  3 +-
 .../framework/recipes/queue/TestQueueSharder.java  |  3 +-
 .../recipes/queue/TestSimpleDistributedQueue.java  |  3 +-
 .../framework/recipes/shared/TestSharedCount.java  |  2 +-
 .../recipes/watch/TestPersistentWatcher.java       |  2 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-test-zk35/pom.xml                          |  8 +++--
 .../curator/framework/TestCompatibility.java       |  3 +-
 .../java/org/apache/curator/zk35/TestIs35.java     |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-test-zk36/pom.xml                          |  8 +++--
 .../java/org/apache/curator/zk36/TestIs36.java     |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-test/pom.xml                               |  4 ++-
 .../org/apache/curator/test/BaseClassForTests.java |  2 +-
 .../org/apache/curator/test/Compatibility.java     |  3 +-
 .../curator/test/DelegatingExecutorService.java    |  3 +-
 .../org/apache/curator/test/DirectoryUtils.java    |  3 +-
 .../test/ExecuteCalledWatchingExecutorService.java |  3 +-
 .../curator/test/FailedServerStartException.java   |  3 +-
 .../java/org/apache/curator/test/InstanceSpec.java |  2 +-
 .../java/org/apache/curator/test/KillSession.java  |  3 +-
 .../apache/curator/test/QuorumConfigBuilder.java   |  2 +-
 .../curator/test/QuorumPeerConfigBuilder.java      |  2 +-
 .../java/org/apache/curator/test/ServerHelper.java |  3 +-
 .../org/apache/curator/test/TestingCluster.java    |  3 +-
 .../apache/curator/test/TestingQuorumPeerMain.java |  3 +-
 .../org/apache/curator/test/TestingServer.java     |  2 +-
 .../apache/curator/test/TestingZooKeeperMain.java  |  2 +-
 .../curator/test/TestingZooKeeperServer.java       |  2 +-
 .../main/java/org/apache/curator/test/Timing.java  |  2 +-
 .../org/apache/curator/test/WatchersDebug.java     |  3 +-
 .../org/apache/curator/test/ZooKeeperMainFace.java |  3 +-
 .../test/ZooKeeperServerEmbeddedAdapter.java       |  2 +-
 .../test/compatibility/CuratorTestBase.java        |  3 +-
 .../apache/curator/test/compatibility/Timing2.java |  2 +-
 .../curator/test/TestQuorumConfigBuilder.java      |  3 +-
 .../org/apache/curator/test/TestTestingServer.java |  3 +-
 curator-x-async/pom.xml                            |  4 ++-
 .../curator/x/async/AsyncCuratorFramework.java     |  3 +-
 .../curator/x/async/AsyncEventException.java       |  3 +-
 .../org/apache/curator/x/async/AsyncResult.java    |  3 +-
 .../org/apache/curator/x/async/AsyncStage.java     |  3 +-
 .../org/apache/curator/x/async/AsyncWrappers.java  |  3 +-
 .../java/org/apache/curator/x/async/WatchMode.java |  3 +-
 .../curator/x/async/api/AsyncCreateBuilder.java    |  3 +-
 .../x/async/api/AsyncCuratorFrameworkDsl.java      |  3 +-
 .../curator/x/async/api/AsyncDeleteBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncEnsemblable.java      |  3 +-
 .../curator/x/async/api/AsyncExistsBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncGetACLBuilder.java    |  3 +-
 .../x/async/api/AsyncGetChildrenBuilder.java       |  3 +-
 .../curator/x/async/api/AsyncGetConfigBuilder.java |  3 +-
 .../curator/x/async/api/AsyncGetDataBuilder.java   |  3 +-
 .../curator/x/async/api/AsyncMultiTransaction.java |  3 +-
 .../curator/x/async/api/AsyncPathAndBytesable.java |  2 +-
 .../apache/curator/x/async/api/AsyncPathable.java  |  3 +-
 .../curator/x/async/api/AsyncReconfigBuilder.java  |  3 +-
 .../x/async/api/AsyncRemoveWatchesBuilder.java     |  3 +-
 .../curator/x/async/api/AsyncSetACLBuilder.java    |  3 +-
 .../curator/x/async/api/AsyncSetDataBuilder.java   |  3 +-
 .../curator/x/async/api/AsyncSyncBuilder.java      |  3 +-
 .../x/async/api/AsyncTransactionCheckBuilder.java  |  3 +-
 .../x/async/api/AsyncTransactionCreateBuilder.java |  2 +-
 .../x/async/api/AsyncTransactionDeleteBuilder.java |  3 +-
 .../curator/x/async/api/AsyncTransactionOp.java    |  3 +-
 .../async/api/AsyncTransactionSetDataBuilder.java  |  3 +-
 .../curator/x/async/api/AsyncWatchBuilder.java     |  2 +-
 .../curator/x/async/api/AsyncWatchBuilder2.java    |  2 +-
 .../apache/curator/x/async/api/CreateOption.java   |  3 +-
 .../apache/curator/x/async/api/DeleteOption.java   |  3 +-
 .../apache/curator/x/async/api/ExistsOption.java   |  3 +-
 .../curator/x/async/api/RemoveWatcherOption.java   |  3 +-
 .../async/api/WatchableAsyncCuratorFramework.java  |  3 +-
 .../x/async/details/AsyncCreateBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncCuratorFrameworkImpl.java |  3 +-
 .../x/async/details/AsyncDeleteBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncExistsBuilderImpl.java    |  3 +-
 .../async/details/AsyncGetChildrenBuilderImpl.java |  3 +-
 .../x/async/details/AsyncGetConfigBuilderImpl.java |  3 +-
 .../x/async/details/AsyncGetDataBuilderImpl.java   |  3 +-
 .../x/async/details/AsyncReconfigBuilderImpl.java  |  3 +-
 .../details/AsyncRemoveWatchesBuilderImpl.java     |  3 +-
 .../curator/x/async/details/AsyncResultImpl.java   |  3 +-
 .../x/async/details/AsyncSetACLBuilderImpl.java    |  3 +-
 .../x/async/details/AsyncSetDataBuilderImpl.java   |  3 +-
 .../x/async/details/AsyncTransactionOpImpl.java    |  3 +-
 .../x/async/details/AsyncWatchBuilderImpl.java     |  2 +-
 .../curator/x/async/details/BackgroundProc.java    |  3 +-
 .../curator/x/async/details/BackgroundProcs.java   |  3 +-
 .../curator/x/async/details/BuilderCommon.java     |  3 +-
 .../apache/curator/x/async/details/Filters.java    |  3 +-
 .../curator/x/async/details/InternalCallback.java  |  3 +-
 .../curator/x/async/details/InternalWatcher.java   |  3 +-
 .../curator/x/async/migrations/Migration.java      |  3 +-
 .../x/async/migrations/MigrationException.java     |  3 +-
 .../x/async/migrations/MigrationManager.java       |  3 +-
 .../curator/x/async/migrations/MigrationSet.java   |  3 +-
 .../x/async/modeled/JacksonModelSerializer.java    |  3 +-
 .../curator/x/async/modeled/ModelSerializer.java   |  3 +-
 .../apache/curator/x/async/modeled/ModelSpec.java  |  3 +-
 .../curator/x/async/modeled/ModelSpecBuilder.java  |  3 +-
 .../curator/x/async/modeled/ModeledFramework.java  |  3 +-
 .../x/async/modeled/ModeledFrameworkBuilder.java   |  3 +-
 .../curator/x/async/modeled/ModeledOptions.java    |  3 +-
 .../apache/curator/x/async/modeled/NodeName.java   |  3 +-
 .../apache/curator/x/async/modeled/Resolvable.java |  3 +-
 .../org/apache/curator/x/async/modeled/ZNode.java  |  3 +-
 .../org/apache/curator/x/async/modeled/ZPath.java  |  3 +-
 .../modeled/cached/CachedModeledFramework.java     |  3 +-
 .../x/async/modeled/cached/ModeledCache.java       |  3 +-
 .../async/modeled/cached/ModeledCacheListener.java |  3 +-
 .../details/CachedModeledFrameworkImpl.java        |  3 +-
 .../x/async/modeled/details/ModelSpecImpl.java     |  3 +-
 .../x/async/modeled/details/ModelStage.java        |  3 +-
 .../x/async/modeled/details/ModeledCacheImpl.java  |  3 +-
 .../modeled/details/ModeledFrameworkImpl.java      |  3 +-
 .../details/VersionedModeledFrameworkImpl.java     |  3 +-
 .../curator/x/async/modeled/details/ZNodeImpl.java |  3 +-
 .../curator/x/async/modeled/details/ZPathImpl.java |  3 +-
 .../x/async/modeled/typed/TypedModelSpec.java      |  3 +-
 .../x/async/modeled/typed/TypedModelSpec0.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec10.java    |  3 +-
 .../x/async/modeled/typed/TypedModelSpec2.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec3.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec4.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec5.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec6.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec7.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec8.java     |  3 +-
 .../x/async/modeled/typed/TypedModelSpec9.java     |  3 +-
 .../async/modeled/typed/TypedModeledFramework.java |  3 +-
 .../modeled/typed/TypedModeledFramework0.java      |  3 +-
 .../modeled/typed/TypedModeledFramework10.java     |  3 +-
 .../modeled/typed/TypedModeledFramework2.java      |  3 +-
 .../modeled/typed/TypedModeledFramework3.java      |  3 +-
 .../modeled/typed/TypedModeledFramework4.java      |  3 +-
 .../modeled/typed/TypedModeledFramework5.java      |  3 +-
 .../modeled/typed/TypedModeledFramework6.java      |  3 +-
 .../modeled/typed/TypedModeledFramework7.java      |  3 +-
 .../modeled/typed/TypedModeledFramework8.java      |  3 +-
 .../modeled/typed/TypedModeledFramework9.java      |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath.java  |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath0.java |  3 +-
 .../x/async/modeled/typed/TypedZPath10.java        |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath2.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath3.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath4.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath5.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath6.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath7.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath8.java |  3 +-
 .../curator/x/async/modeled/typed/TypedZPath9.java |  3 +-
 .../x/async/modeled/versioned/Versioned.java       |  3 +-
 .../versioned/VersionedModeledFramework.java       |  3 +-
 .../curator/framework/imps/TestAddWatch.java       |  3 +-
 .../curator/framework/imps/TestFramework.java      |  3 +-
 .../framework/imps/TestFrameworkBackground.java    |  3 +-
 .../x/async/CompletableBaseClassForTests.java      |  3 +-
 .../apache/curator/x/async/TestAsyncWrappers.java  |  3 +-
 .../curator/x/async/TestBasicOperations.java       |  3 +-
 .../x/async/migrations/TestMigrationManager.java   |  3 +-
 .../curator/x/async/migrations/models/ModelV1.java |  3 +-
 .../curator/x/async/migrations/models/ModelV2.java |  3 +-
 .../curator/x/async/migrations/models/ModelV3.java |  3 +-
 .../async/modeled/TestCachedModeledFramework.java  |  3 +-
 .../x/async/modeled/TestModeledFramework.java      |  2 +-
 .../x/async/modeled/TestModeledFrameworkBase.java  |  3 +-
 .../apache/curator/x/async/modeled/TestZPath.java  |  3 +-
 .../curator/x/async/modeled/models/TestModel.java  |  3 +-
 .../x/async/modeled/models/TestNewerModel.java     |  3 +-
 .../x/async/modeled/models/TestSimpleModel.java    |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-x-discovery-server/pom.xml                 |  4 ++-
 .../server/contexts/GenericDiscoveryContext.java   |  3 +-
 .../server/contexts/IntegerDiscoveryContext.java   |  3 +-
 .../server/contexts/MapDiscoveryContext.java       |  3 +-
 .../server/contexts/StringDiscoveryContext.java    |  3 +-
 .../entity/JsonServiceInstanceMarshaller.java      |  3 +-
 .../entity/JsonServiceInstancesMarshaller.java     |  3 +-
 .../server/entity/JsonServiceNamesMarshaller.java  |  3 +-
 .../discovery/server/entity/ServiceInstances.java  |  3 +-
 .../x/discovery/server/entity/ServiceNames.java    |  3 +-
 .../x/discovery/server/rest/DiscoveryContext.java  |  3 +-
 .../x/discovery/server/rest/DiscoveryResource.java |  3 +-
 .../x/discovery/server/rest/InstanceCleanup.java   |  3 +-
 .../server/jetty_jersey/MapDiscoveryResource.java  |  3 +-
 .../server/jetty_jersey/ServiceDetails.java        |  3 +-
 .../ServiceDetailsDiscoveryContext.java            |  3 +-
 .../ServiceDetailsDiscoveryResource.java           |  3 +-
 .../jetty_jersey/StringDiscoveryResource.java      |  3 +-
 .../server/jetty_jersey/TestMapsWithJersey.java    |  3 +-
 .../jetty_jersey/TestObjectPayloadWithJersey.java  |  3 +-
 .../server/jetty_jersey/TestStringsWithJersey.java |  3 +-
 .../server/jetty_resteasy/RestEasyApplication.java |  3 +-
 .../server/jetty_resteasy/RestEasySingletons.java  |  3 +-
 .../jetty_resteasy/StringDiscoveryResource.java    |  3 +-
 .../jetty_resteasy/TestStringsWithRestEasy.java    |  3 +-
 .../server/mocks/MockServiceDiscovery.java         |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 curator-x-discovery/pom.xml                        |  4 ++-
 .../curator/x/discovery/DownInstancePolicy.java    |  2 +-
 .../apache/curator/x/discovery/InstanceFilter.java |  3 +-
 .../apache/curator/x/discovery/LocalIpFilter.java  |  3 +-
 .../curator/x/discovery/ProviderStrategy.java      |  3 +-
 .../apache/curator/x/discovery/ServiceCache.java   |  3 +-
 .../curator/x/discovery/ServiceCacheBuilder.java   |  3 +-
 .../curator/x/discovery/ServiceDiscovery.java      |  3 +-
 .../x/discovery/ServiceDiscoveryBuilder.java       |  2 +-
 .../curator/x/discovery/ServiceInstance.java       |  3 +-
 .../x/discovery/ServiceInstanceBuilder.java        |  3 +-
 .../curator/x/discovery/ServiceProvider.java       |  2 +-
 .../x/discovery/ServiceProviderBuilder.java        |  3 +-
 .../apache/curator/x/discovery/ServiceType.java    |  3 +-
 .../org/apache/curator/x/discovery/UriSpec.java    |  3 +-
 .../x/discovery/details/DownInstanceManager.java   |  3 +-
 .../details/FilteredInstanceProvider.java          |  3 +-
 .../x/discovery/details/InstanceProvider.java      |  3 +-
 .../x/discovery/details/InstanceSerializer.java    |  3 +-
 .../discovery/details/JsonInstanceSerializer.java  |  2 +-
 .../apache/curator/x/discovery/details/Latch.java  |  3 +-
 .../x/discovery/details/OldServiceInstance.java    |  2 +-
 .../discovery/details/ServiceCacheBuilderImpl.java |  3 +-
 .../x/discovery/details/ServiceCacheImpl.java      |  2 +-
 .../x/discovery/details/ServiceCacheListener.java  |  3 +-
 .../x/discovery/details/ServiceDiscoveryImpl.java  |  2 +-
 .../details/ServiceProviderBuilderImpl.java        |  3 +-
 .../x/discovery/details/ServiceProviderImpl.java   |  3 +-
 .../x/discovery/strategies/RandomStrategy.java     |  3 +-
 .../x/discovery/strategies/RoundRobinStrategy.java |  3 +-
 .../x/discovery/strategies/StickyStrategy.java     |  3 +-
 .../x/discovery/ServiceCacheLeakTester.java        |  3 +-
 .../x/discovery/TestJsonInstanceSerializer.java    |  3 +-
 .../curator/x/discovery/TestLocalIpFilter.java     |  3 +-
 .../curator/x/discovery/TestServiceCache.java      |  2 +-
 .../apache/curator/x/discovery/TestStrategies.java |  3 +-
 .../apache/curator/x/discovery/TestUriSpec.java    |  3 +-
 .../discovery/details/TestDownInstanceManager.java |  3 +-
 .../TestJsonInstanceSerializerCompatibility.java   |  2 +-
 .../discovery/details/TestNewServiceInstance.java  |  3 +-
 .../x/discovery/details/TestServiceCacheRace.java  |  3 +-
 .../x/discovery/details/TestServiceDiscovery.java  |  2 +-
 .../details/TestServiceDiscoveryBuilder.java       |  3 +-
 .../x/discovery/details/TestServiceProvider.java   |  3 +-
 .../x/discovery/details/TestWatchedInstances.java  |  3 +-
 .../src/test/resources/log4j.properties            |  2 --
 merge-pr.py                                        | 29 +++++++++--------
 pom.xml                                            |  7 ++--
 716 files changed, 1413 insertions(+), 846 deletions(-)

diff --git a/curator-client/pom.xml b/curator-client/pom.xml
index 3577c0f8..88cb72e3 100644
--- a/curator-client/pom.xml
+++ b/curator-client/pom.xml
@@ -1,4 +1,6 @@
-<?xml version="1.0" encoding="UTF-8"?><!--
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -15,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 https://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/curator-client/src/main/java/org/apache/curator/ConnectionState.java b/curator-client/src/main/java/org/apache/curator/ConnectionState.java
index fda0a4b2..88325f22 100644
--- a/curator-client/src/main/java/org/apache/curator/ConnectionState.java
+++ b/curator-client/src/main/java/org/apache/curator/ConnectionState.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.curator.drivers.EventTrace;
diff --git a/curator-client/src/main/java/org/apache/curator/CuratorConnectionLossException.java b/curator-client/src/main/java/org/apache/curator/CuratorConnectionLossException.java
index bd5c7ae5..2df63f42 100644
--- a/curator-client/src/main/java/org/apache/curator/CuratorConnectionLossException.java
+++ b/curator-client/src/main/java/org/apache/curator/CuratorConnectionLossException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.zookeeper.KeeperException;
diff --git a/curator-client/src/main/java/org/apache/curator/CuratorZookeeperClient.java b/curator-client/src/main/java/org/apache/curator/CuratorZookeeperClient.java
index f266b387..51cad402 100644
--- a/curator-client/src/main/java/org/apache/curator/CuratorZookeeperClient.java
+++ b/curator-client/src/main/java/org/apache/curator/CuratorZookeeperClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/HandleHolder.java b/curator-client/src/main/java/org/apache/curator/HandleHolder.java
index e87cf4a6..a8c6d53d 100644
--- a/curator-client/src/main/java/org/apache/curator/HandleHolder.java
+++ b/curator-client/src/main/java/org/apache/curator/HandleHolder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.curator.ensemble.EnsembleProvider;
diff --git a/curator-client/src/main/java/org/apache/curator/Helper.java b/curator-client/src/main/java/org/apache/curator/Helper.java
index d38c47eb..31b4aa64 100644
--- a/curator-client/src/main/java/org/apache/curator/Helper.java
+++ b/curator-client/src/main/java/org/apache/curator/Helper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.zookeeper.ZooKeeper;
diff --git a/curator-client/src/main/java/org/apache/curator/RetryLoop.java b/curator-client/src/main/java/org/apache/curator/RetryLoop.java
index 070d9b35..85a79cae 100644
--- a/curator-client/src/main/java/org/apache/curator/RetryLoop.java
+++ b/curator-client/src/main/java/org/apache/curator/RetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.curator.connection.ThreadLocalRetryLoop;
diff --git a/curator-client/src/main/java/org/apache/curator/RetryLoopImpl.java b/curator-client/src/main/java/org/apache/curator/RetryLoopImpl.java
index d987f9fa..85991274 100644
--- a/curator-client/src/main/java/org/apache/curator/RetryLoopImpl.java
+++ b/curator-client/src/main/java/org/apache/curator/RetryLoopImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/RetryPolicy.java b/curator-client/src/main/java/org/apache/curator/RetryPolicy.java
index 6d5d4d12..2f0a79ab 100644
--- a/curator-client/src/main/java/org/apache/curator/RetryPolicy.java
+++ b/curator-client/src/main/java/org/apache/curator/RetryPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.zookeeper.KeeperException;
diff --git a/curator-client/src/main/java/org/apache/curator/RetrySleeper.java b/curator-client/src/main/java/org/apache/curator/RetrySleeper.java
index fa254f3d..034563cd 100644
--- a/curator-client/src/main/java/org/apache/curator/RetrySleeper.java
+++ b/curator-client/src/main/java/org/apache/curator/RetrySleeper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import java.util.concurrent.TimeUnit;
diff --git a/curator-client/src/main/java/org/apache/curator/SessionFailRetryLoop.java b/curator-client/src/main/java/org/apache/curator/SessionFailRetryLoop.java
index 65c5c977..e81c275e 100644
--- a/curator-client/src/main/java/org/apache/curator/SessionFailRetryLoop.java
+++ b/curator-client/src/main/java/org/apache/curator/SessionFailRetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-client/src/main/java/org/apache/curator/SessionFailedRetryPolicy.java b/curator-client/src/main/java/org/apache/curator/SessionFailedRetryPolicy.java
index 07f8697d..d645e36c 100644
--- a/curator-client/src/main/java/org/apache/curator/SessionFailedRetryPolicy.java
+++ b/curator-client/src/main/java/org/apache/curator/SessionFailedRetryPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.zookeeper.KeeperException;
diff --git a/curator-client/src/main/java/org/apache/curator/TimeTrace.java b/curator-client/src/main/java/org/apache/curator/TimeTrace.java
index ede000a0..723f59db 100644
--- a/curator-client/src/main/java/org/apache/curator/TimeTrace.java
+++ b/curator-client/src/main/java/org/apache/curator/TimeTrace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.curator.drivers.TracerDriver;
diff --git a/curator-client/src/main/java/org/apache/curator/connection/ThreadLocalRetryLoop.java b/curator-client/src/main/java/org/apache/curator/connection/ThreadLocalRetryLoop.java
index c7a0c1ff..40e14bb5 100644
--- a/curator-client/src/main/java/org/apache/curator/connection/ThreadLocalRetryLoop.java
+++ b/curator-client/src/main/java/org/apache/curator/connection/ThreadLocalRetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.connection;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-client/src/main/java/org/apache/curator/drivers/AdvancedTracerDriver.java b/curator-client/src/main/java/org/apache/curator/drivers/AdvancedTracerDriver.java
index 40faa999..2644f2fa 100644
--- a/curator-client/src/main/java/org/apache/curator/drivers/AdvancedTracerDriver.java
+++ b/curator-client/src/main/java/org/apache/curator/drivers/AdvancedTracerDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.drivers;
 
 import java.util.concurrent.TimeUnit;
diff --git a/curator-client/src/main/java/org/apache/curator/drivers/EventTrace.java b/curator-client/src/main/java/org/apache/curator/drivers/EventTrace.java
index 1c6e0314..6d1f6ac4 100644
--- a/curator-client/src/main/java/org/apache/curator/drivers/EventTrace.java
+++ b/curator-client/src/main/java/org/apache/curator/drivers/EventTrace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.drivers;
 
 public class EventTrace
diff --git a/curator-client/src/main/java/org/apache/curator/drivers/OperationTrace.java b/curator-client/src/main/java/org/apache/curator/drivers/OperationTrace.java
index b8de3a3c..f84c1c56 100644
--- a/curator-client/src/main/java/org/apache/curator/drivers/OperationTrace.java
+++ b/curator-client/src/main/java/org/apache/curator/drivers/OperationTrace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.drivers;
 
 import org.apache.curator.drivers.TracerDriver;
diff --git a/curator-client/src/main/java/org/apache/curator/drivers/TracerDriver.java b/curator-client/src/main/java/org/apache/curator/drivers/TracerDriver.java
index 402343af..69021ed2 100644
--- a/curator-client/src/main/java/org/apache/curator/drivers/TracerDriver.java
+++ b/curator-client/src/main/java/org/apache/curator/drivers/TracerDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.drivers;
 
 import java.util.concurrent.TimeUnit;
diff --git a/curator-client/src/main/java/org/apache/curator/ensemble/EnsembleProvider.java b/curator-client/src/main/java/org/apache/curator/ensemble/EnsembleProvider.java
index 4db83482..24f32f06 100644
--- a/curator-client/src/main/java/org/apache/curator/ensemble/EnsembleProvider.java
+++ b/curator-client/src/main/java/org/apache/curator/ensemble/EnsembleProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.ensemble;
 
 import org.apache.curator.CuratorZookeeperClient;
diff --git a/curator-client/src/main/java/org/apache/curator/ensemble/fixed/FixedEnsembleProvider.java b/curator-client/src/main/java/org/apache/curator/ensemble/fixed/FixedEnsembleProvider.java
index 0762607a..95a0511a 100644
--- a/curator-client/src/main/java/org/apache/curator/ensemble/fixed/FixedEnsembleProvider.java
+++ b/curator-client/src/main/java/org/apache/curator/ensemble/fixed/FixedEnsembleProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.ensemble.fixed;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-client/src/main/java/org/apache/curator/retry/BoundedExponentialBackoffRetry.java b/curator-client/src/main/java/org/apache/curator/retry/BoundedExponentialBackoffRetry.java
index 3c9d3cda..b85588c6 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/BoundedExponentialBackoffRetry.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/BoundedExponentialBackoffRetry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-client/src/main/java/org/apache/curator/retry/ExponentialBackoffRetry.java b/curator-client/src/main/java/org/apache/curator/retry/ExponentialBackoffRetry.java
index 421e2b24..e9f56f30 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/ExponentialBackoffRetry.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/ExponentialBackoffRetry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-client/src/main/java/org/apache/curator/retry/RetryForever.java b/curator-client/src/main/java/org/apache/curator/retry/RetryForever.java
index 59f3d0d3..c8431383 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/RetryForever.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/RetryForever.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-client/src/main/java/org/apache/curator/retry/RetryNTimes.java b/curator-client/src/main/java/org/apache/curator/retry/RetryNTimes.java
index 234b2416..71b5ed78 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/RetryNTimes.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/RetryNTimes.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 /**
diff --git a/curator-client/src/main/java/org/apache/curator/retry/RetryOneTime.java b/curator-client/src/main/java/org/apache/curator/retry/RetryOneTime.java
index 5fe286da..cac6e0a5 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/RetryOneTime.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/RetryOneTime.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 /**
diff --git a/curator-client/src/main/java/org/apache/curator/retry/RetryUntilElapsed.java b/curator-client/src/main/java/org/apache/curator/retry/RetryUntilElapsed.java
index 3b11268b..3ce006e0 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/RetryUntilElapsed.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/RetryUntilElapsed.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 import org.apache.curator.RetrySleeper;
diff --git a/curator-client/src/main/java/org/apache/curator/retry/SleepingRetry.java b/curator-client/src/main/java/org/apache/curator/retry/SleepingRetry.java
index 22d2b33a..8b729f53 100644
--- a/curator-client/src/main/java/org/apache/curator/retry/SleepingRetry.java
+++ b/curator-client/src/main/java/org/apache/curator/retry/SleepingRetry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.retry;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/CloseableExecutorService.java b/curator-client/src/main/java/org/apache/curator/utils/CloseableExecutorService.java
index 6a84bc47..29089637 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/CloseableExecutorService.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/CloseableExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/CloseableScheduledExecutorService.java b/curator-client/src/main/java/org/apache/curator/utils/CloseableScheduledExecutorService.java
index 989293cc..5b832b74 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/CloseableScheduledExecutorService.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/CloseableScheduledExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/CloseableUtils.java b/curator-client/src/main/java/org/apache/curator/utils/CloseableUtils.java
index 1082afb7..fd0a84f9 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/CloseableUtils.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/CloseableUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/Compatibility.java b/curator-client/src/main/java/org/apache/curator/utils/Compatibility.java
index 4afc8e5a..4fb1979e 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/Compatibility.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/Compatibility.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/ConfigurableZookeeperFactory.java b/curator-client/src/main/java/org/apache/curator/utils/ConfigurableZookeeperFactory.java
index 5aa0c4b2..6a8d6e83 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/ConfigurableZookeeperFactory.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/ConfigurableZookeeperFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/DebugUtils.java b/curator-client/src/main/java/org/apache/curator/utils/DebugUtils.java
index 7ac4c4d5..0cc4227a 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/DebugUtils.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/DebugUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/DefaultTracerDriver.java b/curator-client/src/main/java/org/apache/curator/utils/DefaultTracerDriver.java
index fa3a0c8e..5439421a 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/DefaultTracerDriver.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/DefaultTracerDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import org.apache.curator.drivers.TracerDriver;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/DefaultZookeeperFactory.java b/curator-client/src/main/java/org/apache/curator/utils/DefaultZookeeperFactory.java
index acd32e7d..c9bf1971 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/DefaultZookeeperFactory.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/DefaultZookeeperFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/EnsurePath.java b/curator-client/src/main/java/org/apache/curator/utils/EnsurePath.java
index 3845a749..2843f344 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/EnsurePath.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/EnsurePath.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/ExceptionAccumulator.java b/curator-client/src/main/java/org/apache/curator/utils/ExceptionAccumulator.java
index ee93ea9c..932c2274 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/ExceptionAccumulator.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/ExceptionAccumulator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import com.google.common.base.Throwables;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/InternalACLProvider.java b/curator-client/src/main/java/org/apache/curator/utils/InternalACLProvider.java
index 661a55fd..13e79e54 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/InternalACLProvider.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/InternalACLProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/NonAdminZookeeperFactory.java b/curator-client/src/main/java/org/apache/curator/utils/NonAdminZookeeperFactory.java
index 6163df53..cb36a729 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/NonAdminZookeeperFactory.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/NonAdminZookeeperFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/PathUtils.java b/curator-client/src/main/java/org/apache/curator/utils/PathUtils.java
index 4fcf05b2..110f3b0e 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/PathUtils.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/PathUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 /**
diff --git a/curator-client/src/main/java/org/apache/curator/utils/ThreadUtils.java b/curator-client/src/main/java/org/apache/curator/utils/ThreadUtils.java
index bc936047..a89963e1 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/ThreadUtils.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/ThreadUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import com.google.common.base.Throwables;
diff --git a/curator-client/src/main/java/org/apache/curator/utils/ZKPaths.java b/curator-client/src/main/java/org/apache/curator/utils/ZKPaths.java
index a7a9bd20..0e762573 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/ZKPaths.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/ZKPaths.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/main/java/org/apache/curator/utils/ZookeeperFactory.java b/curator-client/src/main/java/org/apache/curator/utils/ZookeeperFactory.java
index 1d48fac3..eaa80ebb 100644
--- a/curator-client/src/main/java/org/apache/curator/utils/ZookeeperFactory.java
+++ b/curator-client/src/main/java/org/apache/curator/utils/ZookeeperFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-client/src/test/java/org/apache/curator/BasicTests.java b/curator-client/src/test/java/org/apache/curator/BasicTests.java
index 7d419d4d..a81dbcbe 100644
--- a/curator-client/src/test/java/org/apache/curator/BasicTests.java
+++ b/curator-client/src/test/java/org/apache/curator/BasicTests.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-client/src/test/java/org/apache/curator/TestEnsurePath.java b/curator-client/src/test/java/org/apache/curator/TestEnsurePath.java
index 21d65c9b..39e1601c 100644
--- a/curator-client/src/test/java/org/apache/curator/TestEnsurePath.java
+++ b/curator-client/src/test/java/org/apache/curator/TestEnsurePath.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
diff --git a/curator-client/src/test/java/org/apache/curator/TestIs37.java b/curator-client/src/test/java/org/apache/curator/TestIs37.java
index 55c5690c..73020ede 100644
--- a/curator-client/src/test/java/org/apache/curator/TestIs37.java
+++ b/curator-client/src/test/java/org/apache/curator/TestIs37.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import org.apache.curator.test.compatibility.CuratorTestBase;
diff --git a/curator-client/src/test/java/org/apache/curator/TestRetryLoop.java b/curator-client/src/test/java/org/apache/curator/TestRetryLoop.java
index abdc82e2..69ebbae0 100644
--- a/curator-client/src/test/java/org/apache/curator/TestRetryLoop.java
+++ b/curator-client/src/test/java/org/apache/curator/TestRetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import static org.assertj.core.api.Assertions.assertThat;
diff --git a/curator-client/src/test/java/org/apache/curator/TestSessionFailRetryLoop.java b/curator-client/src/test/java/org/apache/curator/TestSessionFailRetryLoop.java
index 049ee889..7459c1e7 100644
--- a/curator-client/src/test/java/org/apache/curator/TestSessionFailRetryLoop.java
+++ b/curator-client/src/test/java/org/apache/curator/TestSessionFailRetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator;
 
 import static org.junit.jupiter.api.Assertions.assertFalse;
diff --git a/curator-client/src/test/java/org/apache/curator/utils/TestCloseableExecutorService.java b/curator-client/src/test/java/org/apache/curator/utils/TestCloseableExecutorService.java
index dd189d8b..1a3fa72f 100644
--- a/curator-client/src/test/java/org/apache/curator/utils/TestCloseableExecutorService.java
+++ b/curator-client/src/test/java/org/apache/curator/utils/TestCloseableExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/test/java/org/apache/curator/utils/TestCloseableScheduledExecutorService.java b/curator-client/src/test/java/org/apache/curator/utils/TestCloseableScheduledExecutorService.java
index 85be3e33..e854a9f0 100644
--- a/curator-client/src/test/java/org/apache/curator/utils/TestCloseableScheduledExecutorService.java
+++ b/curator-client/src/test/java/org/apache/curator/utils/TestCloseableScheduledExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.utils;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-client/src/test/java/org/apache/curator/utils/TestZKPaths.java b/curator-client/src/test/java/org/apache/curator/utils/TestZKPaths.java
index 5cfaf7b3..05f46a88 100644
--- a/curator-client/src/test/java/org/apache/curator/utils/TestZKPaths.java
+++ b/curator-client/src/test/java/org/apache/curator/utils/TestZKPaths.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-client/src/test/resources/log4j.properties b/curator-client/src/test/resources/log4j.properties
index 2a85e0d1..706484ce 100644
--- a/curator-client/src/test/resources/log4j.properties
+++ b/curator-client/src/test/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-examples/pom.xml b/curator-examples/pom.xml
index bf349b3d..d6b9169b 100644
--- a/curator-examples/pom.xml
+++ b/curator-examples/pom.xml
@@ -1,5 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -16,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 https://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/curator-examples/src/main/java/async/AsyncExamples.java b/curator-examples/src/main/java/async/AsyncExamples.java
index 43db219a..4b67a8c4 100644
--- a/curator-examples/src/main/java/async/AsyncExamples.java
+++ b/curator-examples/src/main/java/async/AsyncExamples.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package async;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-examples/src/main/java/cache/CuratorCacheExample.java b/curator-examples/src/main/java/cache/CuratorCacheExample.java
index f57923a0..11da6ba4 100644
--- a/curator-examples/src/main/java/cache/CuratorCacheExample.java
+++ b/curator-examples/src/main/java/cache/CuratorCacheExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-examples/src/main/java/cache/PathCacheExample.java b/curator-examples/src/main/java/cache/PathCacheExample.java
index e121337c..cbfcc7a8 100644
--- a/curator-examples/src/main/java/cache/PathCacheExample.java
+++ b/curator-examples/src/main/java/cache/PathCacheExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package cache;
 
 import com.google.common.collect.Lists;
diff --git a/curator-examples/src/main/java/cache/TreeCacheExample.java b/curator-examples/src/main/java/cache/TreeCacheExample.java
index 73421f8b..5c49e078 100644
--- a/curator-examples/src/main/java/cache/TreeCacheExample.java
+++ b/curator-examples/src/main/java/cache/TreeCacheExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package cache;
 
 import framework.CreateClientExamples;
diff --git a/curator-examples/src/main/java/discovery/DiscoveryExample.java b/curator-examples/src/main/java/discovery/DiscoveryExample.java
index a7ad398f..e932fa5e 100644
--- a/curator-examples/src/main/java/discovery/DiscoveryExample.java
+++ b/curator-examples/src/main/java/discovery/DiscoveryExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package discovery;
 
 import com.google.common.base.Predicate;
diff --git a/curator-examples/src/main/java/discovery/ExampleServer.java b/curator-examples/src/main/java/discovery/ExampleServer.java
index 96478f5f..9b461ee8 100644
--- a/curator-examples/src/main/java/discovery/ExampleServer.java
+++ b/curator-examples/src/main/java/discovery/ExampleServer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package discovery;
 
 import org.apache.curator.utils.CloseableUtils;
diff --git a/curator-examples/src/main/java/discovery/InstanceDetails.java b/curator-examples/src/main/java/discovery/InstanceDetails.java
index 91e465ae..8c40a979 100644
--- a/curator-examples/src/main/java/discovery/InstanceDetails.java
+++ b/curator-examples/src/main/java/discovery/InstanceDetails.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package discovery;
 
 import com.fasterxml.jackson.annotation.JsonRootName;
diff --git a/curator-examples/src/main/java/framework/CreateClientExamples.java b/curator-examples/src/main/java/framework/CreateClientExamples.java
index 4d3c27ee..31c799c3 100644
--- a/curator-examples/src/main/java/framework/CreateClientExamples.java
+++ b/curator-examples/src/main/java/framework/CreateClientExamples.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package framework;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-examples/src/main/java/framework/CrudExamples.java b/curator-examples/src/main/java/framework/CrudExamples.java
index 029ff442..8ac76098 100644
--- a/curator-examples/src/main/java/framework/CrudExamples.java
+++ b/curator-examples/src/main/java/framework/CrudExamples.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package framework;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-examples/src/main/java/framework/TransactionExamples.java b/curator-examples/src/main/java/framework/TransactionExamples.java
index 7ff8064f..49d7920e 100644
--- a/curator-examples/src/main/java/framework/TransactionExamples.java
+++ b/curator-examples/src/main/java/framework/TransactionExamples.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package framework;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-examples/src/main/java/leader/ExampleClient.java b/curator-examples/src/main/java/leader/ExampleClient.java
index 6ec4a1f9..3b9f22b7 100644
--- a/curator-examples/src/main/java/leader/ExampleClient.java
+++ b/curator-examples/src/main/java/leader/ExampleClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package leader;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-examples/src/main/java/leader/LeaderSelectorExample.java b/curator-examples/src/main/java/leader/LeaderSelectorExample.java
index 85f0598a..1c3de744 100644
--- a/curator-examples/src/main/java/leader/LeaderSelectorExample.java
+++ b/curator-examples/src/main/java/leader/LeaderSelectorExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package leader;
 
 import com.google.common.collect.Lists;
diff --git a/curator-examples/src/main/java/locking/ExampleClientThatLocks.java b/curator-examples/src/main/java/locking/ExampleClientThatLocks.java
index dabe0ea6..5c7cd1d9 100644
--- a/curator-examples/src/main/java/locking/ExampleClientThatLocks.java
+++ b/curator-examples/src/main/java/locking/ExampleClientThatLocks.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package locking;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-examples/src/main/java/locking/FakeLimitedResource.java b/curator-examples/src/main/java/locking/FakeLimitedResource.java
index d6d37fd8..ac578e9b 100644
--- a/curator-examples/src/main/java/locking/FakeLimitedResource.java
+++ b/curator-examples/src/main/java/locking/FakeLimitedResource.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package locking;
 
 import java.util.concurrent.atomic.AtomicBoolean;
diff --git a/curator-examples/src/main/java/locking/LockingExample.java b/curator-examples/src/main/java/locking/LockingExample.java
index d400c43a..bd2026e4 100644
--- a/curator-examples/src/main/java/locking/LockingExample.java
+++ b/curator-examples/src/main/java/locking/LockingExample.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package locking;
 
 import org.apache.curator.utils.CloseableUtils;
diff --git a/curator-examples/src/main/java/modeled/ContainerType.java b/curator-examples/src/main/java/modeled/ContainerType.java
index a36cfaa2..c78a39bd 100644
--- a/curator-examples/src/main/java/modeled/ContainerType.java
+++ b/curator-examples/src/main/java/modeled/ContainerType.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 public class ContainerType
diff --git a/curator-examples/src/main/java/modeled/ModeledCuratorExamples.java b/curator-examples/src/main/java/modeled/ModeledCuratorExamples.java
index e7e363c3..5806ecbc 100644
--- a/curator-examples/src/main/java/modeled/ModeledCuratorExamples.java
+++ b/curator-examples/src/main/java/modeled/ModeledCuratorExamples.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 import org.apache.curator.x.async.AsyncCuratorFramework;
diff --git a/curator-examples/src/main/java/modeled/ModeledCuratorExamplesAlt.java b/curator-examples/src/main/java/modeled/ModeledCuratorExamplesAlt.java
index 859a1f14..f747bf8f 100644
--- a/curator-examples/src/main/java/modeled/ModeledCuratorExamplesAlt.java
+++ b/curator-examples/src/main/java/modeled/ModeledCuratorExamplesAlt.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 import org.apache.curator.x.async.modeled.ModeledFramework;
diff --git a/curator-examples/src/main/java/modeled/PersonId.java b/curator-examples/src/main/java/modeled/PersonId.java
index eabc2863..143c8a46 100644
--- a/curator-examples/src/main/java/modeled/PersonId.java
+++ b/curator-examples/src/main/java/modeled/PersonId.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 import java.util.Objects;
diff --git a/curator-examples/src/main/java/modeled/PersonModel.java b/curator-examples/src/main/java/modeled/PersonModel.java
index f9b91027..52be5d94 100644
--- a/curator-examples/src/main/java/modeled/PersonModel.java
+++ b/curator-examples/src/main/java/modeled/PersonModel.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 import java.util.Objects;
diff --git a/curator-examples/src/main/java/modeled/PersonModelSpec.java b/curator-examples/src/main/java/modeled/PersonModelSpec.java
index f90f6163..79286ebb 100644
--- a/curator-examples/src/main/java/modeled/PersonModelSpec.java
+++ b/curator-examples/src/main/java/modeled/PersonModelSpec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package modeled;
 
 import org.apache.curator.x.async.AsyncCuratorFramework;
diff --git a/curator-examples/src/main/java/pubsub/Clients.java b/curator-examples/src/main/java/pubsub/Clients.java
index c0a81366..82212bf1 100644
--- a/curator-examples/src/main/java/pubsub/Clients.java
+++ b/curator-examples/src/main/java/pubsub/Clients.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub;
 
 import org.apache.curator.x.async.modeled.JacksonModelSerializer;
diff --git a/curator-examples/src/main/java/pubsub/Publisher.java b/curator-examples/src/main/java/pubsub/Publisher.java
index 5c8f7af0..73267e7b 100644
--- a/curator-examples/src/main/java/pubsub/Publisher.java
+++ b/curator-examples/src/main/java/pubsub/Publisher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-examples/src/main/java/pubsub/SubPubTest.java b/curator-examples/src/main/java/pubsub/SubPubTest.java
index 354d5685..861059f8 100644
--- a/curator-examples/src/main/java/pubsub/SubPubTest.java
+++ b/curator-examples/src/main/java/pubsub/SubPubTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub;
 
 import org.apache.curator.framework.CuratorFrameworkFactory;
diff --git a/curator-examples/src/main/java/pubsub/Subscriber.java b/curator-examples/src/main/java/pubsub/Subscriber.java
index 94a6247a..ec2561a0 100644
--- a/curator-examples/src/main/java/pubsub/Subscriber.java
+++ b/curator-examples/src/main/java/pubsub/Subscriber.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub;
 
 import org.apache.curator.x.async.AsyncCuratorFramework;
diff --git a/curator-examples/src/main/java/pubsub/messages/LocationAvailable.java b/curator-examples/src/main/java/pubsub/messages/LocationAvailable.java
index dd90107b..d762373b 100644
--- a/curator-examples/src/main/java/pubsub/messages/LocationAvailable.java
+++ b/curator-examples/src/main/java/pubsub/messages/LocationAvailable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.messages;
 
 import pubsub.models.Message;
diff --git a/curator-examples/src/main/java/pubsub/messages/UserCreated.java b/curator-examples/src/main/java/pubsub/messages/UserCreated.java
index bf753a8c..90fcb21f 100644
--- a/curator-examples/src/main/java/pubsub/messages/UserCreated.java
+++ b/curator-examples/src/main/java/pubsub/messages/UserCreated.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.messages;
 
 import pubsub.models.Message;
diff --git a/curator-examples/src/main/java/pubsub/models/Group.java b/curator-examples/src/main/java/pubsub/models/Group.java
index 07d149fd..0baa6171 100644
--- a/curator-examples/src/main/java/pubsub/models/Group.java
+++ b/curator-examples/src/main/java/pubsub/models/Group.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.models;
 
 import org.apache.curator.x.async.modeled.NodeName;
diff --git a/curator-examples/src/main/java/pubsub/models/Instance.java b/curator-examples/src/main/java/pubsub/models/Instance.java
index 981f113c..68180f9d 100644
--- a/curator-examples/src/main/java/pubsub/models/Instance.java
+++ b/curator-examples/src/main/java/pubsub/models/Instance.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.models;
 
 import org.apache.curator.x.async.modeled.NodeName;
diff --git a/curator-examples/src/main/java/pubsub/models/InstanceType.java b/curator-examples/src/main/java/pubsub/models/InstanceType.java
index 176048ce..1253779e 100644
--- a/curator-examples/src/main/java/pubsub/models/InstanceType.java
+++ b/curator-examples/src/main/java/pubsub/models/InstanceType.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.models;
 
 public enum InstanceType
diff --git a/curator-examples/src/main/java/pubsub/models/Message.java b/curator-examples/src/main/java/pubsub/models/Message.java
index 7d92e995..81e36250 100644
--- a/curator-examples/src/main/java/pubsub/models/Message.java
+++ b/curator-examples/src/main/java/pubsub/models/Message.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.models;
 
 import org.apache.curator.x.async.modeled.NodeName;
diff --git a/curator-examples/src/main/java/pubsub/models/Priority.java b/curator-examples/src/main/java/pubsub/models/Priority.java
index 3b10f751..c0448306 100644
--- a/curator-examples/src/main/java/pubsub/models/Priority.java
+++ b/curator-examples/src/main/java/pubsub/models/Priority.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package pubsub.models;
 
 public enum Priority
diff --git a/curator-examples/src/main/resources/log4j.properties b/curator-examples/src/main/resources/log4j.properties
index 04056707..83e675e3 100644
--- a/curator-examples/src/main/resources/log4j.properties
+++ b/curator-examples/src/main/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-framework/pom.xml b/curator-framework/pom.xml
index f0cefbd0..955c124c 100644
--- a/curator-framework/pom.xml
+++ b/curator-framework/pom.xml
@@ -1,5 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -16,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 https://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/AuthInfo.java b/curator-framework/src/main/java/org/apache/curator/framework/AuthInfo.java
index 2f879c53..7a7a564f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/AuthInfo.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/AuthInfo.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/CuratorFramework.java b/curator-framework/src/main/java/org/apache/curator/framework/CuratorFramework.java
index 7943c61f..1527500e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/CuratorFramework.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/CuratorFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/CuratorFrameworkFactory.java b/curator-framework/src/main/java/org/apache/curator/framework/CuratorFrameworkFactory.java
index 02b4552f..54ace509 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/CuratorFrameworkFactory.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/CuratorFrameworkFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/CuratorTempFramework.java b/curator-framework/src/main/java/org/apache/curator/framework/CuratorTempFramework.java
index 4c347955..b4af0e3a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/CuratorTempFramework.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/CuratorTempFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework;
 
 import org.apache.curator.framework.api.TempGetDataBuilder;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/EnsureContainers.java b/curator-framework/src/main/java/org/apache/curator/framework/EnsureContainers.java
index a0aee61f..f3637ac8 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/EnsureContainers.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/EnsureContainers.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework;
 
 import java.util.concurrent.atomic.AtomicBoolean;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/WatcherRemoveCuratorFramework.java b/curator-framework/src/main/java/org/apache/curator/framework/WatcherRemoveCuratorFramework.java
index 14928986..fb923541 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/WatcherRemoveCuratorFramework.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/WatcherRemoveCuratorFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLBackgroundPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLBackgroundPathAndBytesable.java
index 78cfab46..3e3c9528 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLBackgroundPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLBackgroundPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ACLBackgroundPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeBackgroundPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeBackgroundPathAndBytesable.java
index 915355bc..cefd44fb 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeBackgroundPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeBackgroundPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ACLCreateModeBackgroundPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModePathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModePathAndBytesable.java
index dcd8d29a..43f09515 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModePathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModePathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ACLCreateModePathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeStatBackgroundPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeStatBackgroundPathAndBytesable.java
index 0becfb92..ec3ea961 100755
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeStatBackgroundPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLCreateModeStatBackgroundPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ACLCreateModeStatBackgroundPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLPathAndBytesable.java
index 8d16d508..39047b1d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ACLPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLProvider.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLProvider.java
index e0c5ba92..3d5d04d4 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLProvider.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.utils.InternalACLProvider;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLable.java
index e11f2998..a1964000 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.ZooDefs;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLableExistBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLableExistBuilderMain.java
index c16f4fed..33f4a49b 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ACLableExistBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ACLableExistBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/AddStatConfigEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/AddStatConfigEnsembleable.java
index c60f617f..98b1ea37 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/AddStatConfigEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/AddStatConfigEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder.java
index ad6d4344..bc73ff2f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.AddWatchMode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder2.java b/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder2.java
index 22c0343c..aeec8fbb 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder2.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/AddWatchBuilder2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Addable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Addable.java
index e908f1e0..ea53ad73 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Addable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Addable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/AsyncReconfigurable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/AsyncReconfigurable.java
index fc7fd578..73f83e75 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/AsyncReconfigurable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/AsyncReconfigurable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface AsyncReconfigurable  {
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundCallback.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundCallback.java
index 18089671..3c391ce3 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundCallback.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundCallback.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundEnsembleable.java
index 5f9703aa..8abfb4b2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface BackgroundEnsembleable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathAndBytesable.java
index ce9d4ebf..c189457f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface BackgroundPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathable.java
index 5a053a29..972163b2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface BackgroundPathable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathableQuietlyable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathableQuietlyable.java
index cd887390..4ea9f19a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathableQuietlyable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundPathableQuietlyable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface BackgroundPathableQuietlyable<T> extends BackgroundPathable<T>, Quietly<BackgroundPathable<T>>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundVersionable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundVersionable.java
index bd687886..3b5660e1 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundVersionable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/BackgroundVersionable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface BackgroundVersionable extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Backgroundable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Backgroundable.java
index c1a892e4..05b3a967 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Backgroundable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Backgroundable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import java.util.concurrent.Executor;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ChildrenDeletable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ChildrenDeletable.java
index fc11bf80..9aa13ea5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ChildrenDeletable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ChildrenDeletable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ChildrenDeletable extends BackgroundVersionable
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Compressible.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Compressible.java
index a7d54b03..06891ba5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Compressible.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Compressible.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Compressible<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CompressionProvider.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CompressionProvider.java
index 7cbca5e8..22ed20d2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CompressionProvider.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CompressionProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface CompressionProvider
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ConfigureEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ConfigureEnsembleable.java
index 8c739bc3..bcb127f3 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ConfigureEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ConfigureEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeACLable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeACLable.java
index e821d3b9..c500e9f1 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeACLable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeACLable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.CreateMode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeStatACLable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeStatACLable.java
index 2ebe63e4..304a0224 100755
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeStatACLable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBackgroundModeStatACLable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.CreateMode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder.java
index 5d175e96..68ad0c14 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface CreateBuilder extends CreateBuilderMain, Idempotentable<CreateBuilder2>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder2.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder2.java
index ddc27c3f..c910586a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder2.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilder2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface CreateBuilder2 extends CreateBuilderMain
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilderMain.java
index a90ad3ed..0b3bd1e6 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import java.util.UUID;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateModable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateModable.java
index a12a87d3..2d4b0d78 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateModable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateModable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.CreateMode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateProtectACLCreateModePathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateProtectACLCreateModePathAndBytesable.java
index 9e0c8405..93b3268a 100755
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CreateProtectACLCreateModePathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CreateProtectACLCreateModePathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.CreateMode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEvent.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEvent.java
index 673613c3..6a99f5b6 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEvent.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEvent.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.api.transaction.CuratorTransactionResult;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEventType.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEventType.java
index e593da5d..73cb897d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEventType.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorEventType.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorListener.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorListener.java
index 03b225c0..a6dc5ef9 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorListener.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorWatcher.java b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorWatcher.java
index 79b301f3..c9afaabd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorWatcher.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/CuratorWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.WatchedEvent;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/DataCallbackable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/DataCallbackable.java
index 75ded65a..edb2a9d9 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/DataCallbackable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/DataCallbackable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.AsyncCallback.DataCallback;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Decompressible.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Decompressible.java
index ae8cf86f..35b8ea36 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Decompressible.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Decompressible.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Decompressible<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilder.java
index f8ef805b..cdcb91ba 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface DeleteBuilder extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilderMain.java
index 8c686079..ee091835 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/DeleteBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface DeleteBuilderMain extends GuaranteeableDeletable, ChildrenDeletable
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Ensembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Ensembleable.java
index c8a82fed..5f7df7a1 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Ensembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Ensembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Ensembleable<T> {
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerEnsembleable.java
index 8a1805e3..c5bd2407 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ErrorListenerEnsembleable<T> extends Ensembleable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerMultiTransactionMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerMultiTransactionMain.java
index 2237cd2e..83382ce4 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerMultiTransactionMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerMultiTransactionMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.api.transaction.CuratorMultiTransactionMain;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathAndBytesable.java
index 67f906ac..5e9de350 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ErrorListenerPathAndBytesable<T> extends PathAndBytesable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathable.java
index 45380b86..2787e168 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerPathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ErrorListenerPathable<T> extends Pathable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerReconfigBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerReconfigBuilderMain.java
index ef2f2872..50e44ada 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerReconfigBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ErrorListenerReconfigBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ErrorListenerReconfigBuilderMain extends ReconfigBuilderMain
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilder.java
index 2c0cb475..85d27554 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilderMain.java
index 25196163..c6fedee0 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ExistsBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GetACLBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GetACLBuilder.java
index 2deddc7e..47db7ed8 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GetACLBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GetACLBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.ACL;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GetChildrenBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GetChildrenBuilder.java
index b9e98378..5319c5d7 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GetChildrenBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GetChildrenBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import java.util.List;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GetConfigBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GetConfigBuilder.java
index 3c926d47..7bd43289 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GetConfigBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GetConfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataBuilder.java
index 81bf61a4..66450700 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface GetDataBuilder extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataWatchBackgroundStatable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataWatchBackgroundStatable.java
index 6ffd2b98..a22dabca 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataWatchBackgroundStatable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GetDataWatchBackgroundStatable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface GetDataWatchBackgroundStatable extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Guaranteeable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Guaranteeable.java
index bc033ac5..61cd6349 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Guaranteeable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Guaranteeable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Guaranteeable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/GuaranteeableDeletable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/GuaranteeableDeletable.java
index 7f8139cb..c9e07dd1 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/GuaranteeableDeletable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/GuaranteeableDeletable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Idempotentable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Idempotentable.java
index 9f1af9db..ce253882 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Idempotentable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Idempotentable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Idempotentable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/JoinStatConfigEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/JoinStatConfigEnsembleable.java
index c20387c1..9836dacc 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/JoinStatConfigEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/JoinStatConfigEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Joinable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Joinable.java
index 5cebe4d2..9c3ac022 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Joinable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Joinable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/LeaveStatConfigEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/LeaveStatConfigEnsembleable.java
index b80bd00c..3dbe6b5c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/LeaveStatConfigEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/LeaveStatConfigEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Leaveable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Leaveable.java
index 6ec35428..faaf39b1 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Leaveable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Leaveable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Membersable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Membersable.java
index e1f8d9e1..3abef81f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Membersable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Membersable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ParentACLable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ParentACLable.java
index 023c9c1b..40b4260f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ParentACLable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ParentACLable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.ZooDefs;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/PathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/PathAndBytesable.java
index fc0cf076..70d96710 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/PathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/PathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.CuratorFrameworkFactory;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Pathable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Pathable.java
index 68e1a33f..8e1cd701 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Pathable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Pathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Pathable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModePathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModePathAndBytesable.java
index 1d1df102..04e74bfa 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModePathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModePathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ProtectACLCreateModePathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModeStatPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModeStatPathAndBytesable.java
index 07638d57..8f609924 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModeStatPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ProtectACLCreateModeStatPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface ProtectACLCreateModeStatPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Quietly.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Quietly.java
index ad3762fd..edcef08c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Quietly.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Quietly.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Quietly<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilder.java
index 233558d8..e409d23e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilderMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilderMain.java
index b9d1be32..ae82d399 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilderMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/ReconfigBuilderMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesBuilder.java
index 6cc0b054..06aad2bb 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesBuilder.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesLocal.java b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesLocal.java
index 4a67470e..5c6a19dd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesLocal.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesLocal.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.api;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesType.java b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesType.java
index 84d80935..122cf44b 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesType.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/RemoveWatchesType.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.Watcher.WatcherType;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/SetACLBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/SetACLBuilder.java
index 1de4b560..c27c55e6 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/SetACLBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/SetACLBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBackgroundVersionable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBackgroundVersionable.java
index 600cdaaa..23c91033 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBackgroundVersionable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBackgroundVersionable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBuilder.java
index ed2c3e02..622e2427 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/SetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/StatConfigureEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/StatConfigureEnsembleable.java
index 8b61ab9e..79d50000 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/StatConfigureEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/StatConfigureEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/StatPathable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/StatPathable.java
index 5bfc1a67..dfd9d1a3 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/StatPathable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/StatPathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface StatPathable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Statable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Statable.java
index f6ac3c5f..9953147d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Statable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Statable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/SyncBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/SyncBuilder.java
index 6ae35863..eaa2ceef 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/SyncBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/SyncBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface SyncBuilder extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/TempGetDataBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/TempGetDataBuilder.java
index 48d299eb..a6e19b06 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/TempGetDataBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/TempGetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface TempGetDataBuilder extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/UnhandledErrorListener.java b/curator-framework/src/main/java/org/apache/curator/framework/api/UnhandledErrorListener.java
index 3721d4b2..9a483a11 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/UnhandledErrorListener.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/UnhandledErrorListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.curator.framework.state.ConnectionState;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/VersionPathAndBytesable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/VersionPathAndBytesable.java
index 556fc67f..8ddb739f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/VersionPathAndBytesable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/VersionPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface VersionPathAndBytesable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Versionable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Versionable.java
index 807b9e66..b87102b4 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Versionable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Versionable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Versionable<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchBackgroundEnsembleable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchBackgroundEnsembleable.java
index a0e5a139..00ffb72d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchBackgroundEnsembleable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchBackgroundEnsembleable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface WatchBackgroundEnsembleable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchPathable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchPathable.java
index 89b4f846..b59094d3 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchPathable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchPathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface WatchPathable<T> extends
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/Watchable.java b/curator-framework/src/main/java/org/apache/curator/framework/api/Watchable.java
index c024d103..c66c4c12 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/Watchable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/Watchable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 public interface Watchable<T> extends WatchableBase<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchableBase.java b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchableBase.java
index d8a03cb2..ace5e915 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchableBase.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchableBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api;
 
 import org.apache.zookeeper.Watcher;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchesBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchesBuilder.java
index 3cd55284..55c6b4c8 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/WatchesBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/WatchesBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransaction.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransaction.java
index e919a331..83744dae 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransaction.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransaction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.api.Backgroundable;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransactionMain.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransactionMain.java
index 2425f5b1..db88dcf2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransactionMain.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorMultiTransactionMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorOp.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorOp.java
index 23bc76c5..af0e465c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorOp.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.zookeeper.Op;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransaction.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransaction.java
index 5d60b5c9..1b136851 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransaction.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransaction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionBridge.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionBridge.java
index 6ce38324..6cb371fd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionBridge.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionBridge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 public interface CuratorTransactionBridge
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionFinal.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionFinal.java
index c3e0a6fa..48ba57c7 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionFinal.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionFinal.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import java.util.Collection;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionResult.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionResult.java
index ba757918..40b0c7e0 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionResult.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/CuratorTransactionResult.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/OperationType.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/OperationType.java
index c0aec680..f7d27693 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/OperationType.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/OperationType.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCheckBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCheckBuilder.java
index 6de675c4..d75f1182 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCheckBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCheckBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.api.Pathable;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder.java
index cf8016ef..ced16b5d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 public interface TransactionCreateBuilder<T> extends TransactionCreateBuilder2<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder2.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder2.java
index 420aacf0..502e1403 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder2.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionCreateBuilder2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.api.ACLCreateModePathAndBytesable;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionDeleteBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionDeleteBuilder.java
index d9772909..6b6491a2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionDeleteBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionDeleteBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.api.Pathable;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionOp.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionOp.java
index 84808a16..a082f51a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionOp.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionSetDataBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionSetDataBuilder.java
index 42a08208..5556b108 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionSetDataBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TransactionSetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 import org.apache.curator.framework.api.Compressible;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TypeAndPath.java b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TypeAndPath.java
index b1cea957..834e4a74 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TypeAndPath.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/api/transaction/TypeAndPath.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.api.transaction;
 
 public class TypeAndPath
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ACLing.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ACLing.java
index 84c22441..820cb025 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ACLing.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ACLing.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.collect.ImmutableList;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/AddWatchBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/AddWatchBuilderImpl.java
index 6ad8e739..3bdf87a5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/AddWatchBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/AddWatchBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundOperation.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundOperation.java
index 85701369..22a75c71 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundOperation.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundOperation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 interface BackgroundOperation<T>
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundSyncImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundSyncImpl.java
index ef0b870f..1915bd8b 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundSyncImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/BackgroundSyncImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.drivers.OperationTrace;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/Backgrounding.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/Backgrounding.java
index 0be96703..6a6aab6a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/Backgrounding.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/Backgrounding.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CreateBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CreateBuilderImpl.java
index 26bedec5..adca0160 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CreateBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CreateBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorEventImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorEventImpl.java
index 4aa125fe..e5623510 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorEventImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorEventImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkImpl.java
index 70cb4eb7..3c02a3cd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkState.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkState.java
index b4856102..37b6c8d6 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkState.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorFrameworkState.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionImpl.java
index bdab158a..f68ef78d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionRecord.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionRecord.java
index 06fbecb0..93b4786c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionRecord.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorMultiTransactionRecord.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTempFrameworkImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTempFrameworkImpl.java
index 2f922943..b920e1d4 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTempFrameworkImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTempFrameworkImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTransactionImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTransactionImpl.java
index 34dc6e11..b99bc12c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTransactionImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/CuratorTransactionImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/DefaultACLProvider.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/DefaultACLProvider.java
index 78e9f176..cc782450 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/DefaultACLProvider.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/DefaultACLProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.api.ACLProvider;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/DeleteBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/DeleteBuilderImpl.java
index 3f2e2106..21cfee5a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/DeleteBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/DeleteBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/EnsembleTracker.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/EnsembleTracker.java
index cc4bc438..aef536f9 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/EnsembleTracker.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/EnsembleTracker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ExistsBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ExistsBuilderImpl.java
index caebd3d8..642e9d68 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ExistsBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ExistsBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ExtractingCuratorOp.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ExtractingCuratorOp.java
index 5b179e73..ad893258 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ExtractingCuratorOp.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ExtractingCuratorOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedDeleteManager.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedDeleteManager.java
index 934ae403..c854a947 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedDeleteManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedDeleteManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedOperationManager.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedOperationManager.java
index c09e2eca..1e8101cb 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedOperationManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedOperationManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedRemoveWatchManager.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedRemoveWatchManager.java
index f6356604..f88a287f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedRemoveWatchManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/FailedRemoveWatchManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/FindAndDeleteProtectedNodeInBackground.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/FindAndDeleteProtectedNodeInBackground.java
index de91552c..9798f36e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/FindAndDeleteProtectedNodeInBackground.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/FindAndDeleteProtectedNodeInBackground.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetACLBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetACLBuilderImpl.java
index 620242ba..20fbcb62 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetACLBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetACLBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetChildrenBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetChildrenBuilderImpl.java
index ea7aaafc..26695c23 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetChildrenBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetChildrenBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.collect.Lists;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetConfigBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetConfigBuilderImpl.java
index db2d6e49..54855231 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetConfigBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetConfigBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetDataBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetDataBuilderImpl.java
index 2319b9d4..5f73cbc5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/GetDataBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/GetDataBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/GzipCompressionProvider.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/GzipCompressionProvider.java
index fa357d2f..8e59b6bb 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/GzipCompressionProvider.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/GzipCompressionProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/IdempotentUtils.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/IdempotentUtils.java
index 90126420..91b57a51 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/IdempotentUtils.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/IdempotentUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import java.util.Arrays;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/InternalConnectionHandler.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/InternalConnectionHandler.java
index 65669c32..206c5db7 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/InternalConnectionHandler.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/InternalConnectionHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 interface InternalConnectionHandler
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacade.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacade.java
index 95bf1328..a0508b1c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacade.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacade.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.CuratorZookeeperClient;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacadeCache.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacadeCache.java
index d144c1bd..33e0c33a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacadeCache.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceFacadeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.cache.CacheBuilder;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceImpl.java
index c8dfce74..07b5d8f9 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.CuratorZookeeperClient;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatchedEvent.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatchedEvent.java
index f502825f..981b6977 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatchedEvent.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatchedEvent.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.zookeeper.WatchedEvent;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatcher.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatcher.java
index 29482f5a..851d5a0e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/NamespaceWatcher.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/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
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.base.Objects;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/OperationAndData.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/OperationAndData.java
index 8370415a..88258f40 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/OperationAndData.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/OperationAndData.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/PathAndBytes.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/PathAndBytes.java
index d8ac8154..682602b8 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/PathAndBytes.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/PathAndBytes.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 class PathAndBytes
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedMode.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedMode.java
index 7244cc45..83528031 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedMode.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedMode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedUtils.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedUtils.java
index 09569c40..d5e44f99 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedUtils.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ProtectedUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/ReconfigBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/ReconfigBuilderImpl.java
index c351dbfd..af5a9a43 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/ReconfigBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/ReconfigBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/RemoveWatchesBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/RemoveWatchesBuilderImpl.java
index 3c2c35d1..0aab5822 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/RemoveWatchesBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/RemoveWatchesBuilderImpl.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/SetACLBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/SetACLBuilderImpl.java
index 0153a451..eaafc3bc 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/SetACLBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/SetACLBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/SetDataBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/SetDataBuilderImpl.java
index ef87f6ec..00fb4e11 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/SetDataBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/SetDataBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/StandardInternalConnectionHandler.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/StandardInternalConnectionHandler.java
index be0c7267..827a3538 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/StandardInternalConnectionHandler.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/StandardInternalConnectionHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 class StandardInternalConnectionHandler implements InternalConnectionHandler
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/SyncBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/SyncBuilderImpl.java
index 3dec17c9..a0bb366d 100755
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/SyncBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/SyncBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.drivers.OperationTrace;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/TempGetDataBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/TempGetDataBuilderImpl.java
index 8ee527e2..220018dd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/TempGetDataBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/TempGetDataBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/TransactionOpImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/TransactionOpImpl.java
index 381842b4..6347834f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/TransactionOpImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/TransactionOpImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalFacade.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalFacade.java
index b5685f88..82f32d3d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalFacade.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalFacade.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalManager.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalManager.java
index b9c90447..9ac569bf 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatcherRemovalManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatchesBuilderImpl.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatchesBuilderImpl.java
index 4a273c6e..d80d52b2 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/WatchesBuilderImpl.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/WatchesBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/imps/Watching.java b/curator-framework/src/main/java/org/apache/curator/framework/imps/Watching.java
index 5bad7e73..fef544ab 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/imps/Watching.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/imps/Watching.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/Listenable.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/Listenable.java
index 464fa53f..da9b9b8f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/Listenable.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/Listenable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 import java.util.concurrent.Executor;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerEntry.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerEntry.java
index a1c81641..62e2d05d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerEntry.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerEntry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 import java.util.concurrent.Executor;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerManager.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerManager.java
index 85bc8f90..8a0f96de 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/ListenerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 import java.util.function.Consumer;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/MappingListenerManager.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/MappingListenerManager.java
index 4778acef..d0b57c29 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/MappingListenerManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/MappingListenerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 import org.apache.curator.utils.ThreadUtils;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/StandardListenerManager.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/StandardListenerManager.java
index 82139673..f7d3277c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/StandardListenerManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/StandardListenerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 import java.util.concurrent.Executor;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/listen/UnaryListenerManager.java b/curator-framework/src/main/java/org/apache/curator/framework/listen/UnaryListenerManager.java
index 54497f4a..1a647942 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/listen/UnaryListenerManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/listen/UnaryListenerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.listen;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/DefaultSchemaValidator.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/DefaultSchemaValidator.java
index 1c71fc37..b54f32c5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/DefaultSchemaValidator.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/DefaultSchemaValidator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import org.apache.zookeeper.data.ACL;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/Schema.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/Schema.java
index d86fdb5a..180e6ecd 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/Schema.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/Schema.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaBuilder.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaBuilder.java
index 07ac9763..b477193e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaBuilder.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSet.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSet.java
index 98eeefca..af6eb29c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSet.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSet.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import com.google.common.base.Function;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSetLoader.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSetLoader.java
index bab97c69..fe4a5e14 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSetLoader.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaSetLoader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import com.fasterxml.jackson.databind.JsonNode;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaValidator.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaValidator.java
index a92720fa..a59c1500 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaValidator.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaValidator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import org.apache.zookeeper.data.ACL;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaViolation.java b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaViolation.java
index 7ae07838..8f77b34d 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaViolation.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/schema/SchemaViolation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import com.google.common.collect.ImmutableList;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreaker.java b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreaker.java
index c207128d..77c3fc89 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreaker.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreaker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingConnectionStateListener.java b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingConnectionStateListener.java
index beec66fd..5be1adb3 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingConnectionStateListener.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingConnectionStateListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingManager.java b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingManager.java
index 0d9f7ebf..07fd860f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/CircuitBreakingManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionState.java b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionState.java
index b8368175..587a76e5 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionState.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionState.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.framework.CuratorFrameworkFactory;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateErrorPolicy.java b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateErrorPolicy.java
index 90164846..a44cbd3e 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateErrorPolicy.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateErrorPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListener.java b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListener.java
index d626e3f5..573ffedc 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListener.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListenerManagerFactory.java b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListenerManagerFactory.java
index 8c6497a7..325e60ec 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListenerManagerFactory.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateListenerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import org.apache.curator.RetryPolicy;
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateManager.java b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateManager.java
index 1b5f03b6..17d32d0a 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateManager.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/ConnectionStateManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/SessionConnectionStateErrorPolicy.java b/curator-framework/src/main/java/org/apache/curator/framework/state/SessionConnectionStateErrorPolicy.java
index c494e2b4..0a78ad9f 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/SessionConnectionStateErrorPolicy.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/SessionConnectionStateErrorPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 /**
diff --git a/curator-framework/src/main/java/org/apache/curator/framework/state/StandardConnectionStateErrorPolicy.java b/curator-framework/src/main/java/org/apache/curator/framework/state/StandardConnectionStateErrorPolicy.java
index 9346f6eb..87f4408c 100644
--- a/curator-framework/src/main/java/org/apache/curator/framework/state/StandardConnectionStateErrorPolicy.java
+++ b/curator-framework/src/main/java/org/apache/curator/framework/state/StandardConnectionStateErrorPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 /**
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/ensemble/TestEnsembleProvider.java b/curator-framework/src/test/java/org/apache/curator/framework/ensemble/TestEnsembleProvider.java
index 48917141..7646603f 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/ensemble/TestEnsembleProvider.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/ensemble/TestEnsembleProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.ensemble;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestBlockUntilConnected.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestBlockUntilConnected.java
index 7c5091bf..6d0dea8a 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestBlockUntilConnected.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestBlockUntilConnected.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCleanState.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCleanState.java
index 06e31662..3e6e13c7 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCleanState.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCleanState.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompression.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompression.java
index 613ba9d5..8bb9373a 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompression.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompression.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionNew.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionNew.java
index 7fe28231..bf4a63a3 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionNew.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionNew.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionOld.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionOld.java
index 9de1afbe..66186bfa 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionOld.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCompressionInTransactionOld.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreate.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreate.java
index c3798ce9..f1f24e81 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreate.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreate.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.apache.zookeeper.ZooDefs.Ids.ANYONE_ID_UNSAFE;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreateReturningStat.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreateReturningStat.java
index c053de01..1f743fc1 100755
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreateReturningStat.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestCreateReturningStat.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestDelete.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestDelete.java
index ea6351f3..37deebe0 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestDelete.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestDelete.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.apache.zookeeper.KeeperException.Code.*;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnabledSessionExpiredState.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnabledSessionExpiredState.java
index 92f3748d..2ac49a63 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnabledSessionExpiredState.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnabledSessionExpiredState.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnsureContainers.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnsureContainers.java
index 3943efad..2e6ad8a3 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnsureContainers.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestEnsureContainers.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertNotNull;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestExistsBuilder.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestExistsBuilder.java
index 54704ab4..0ac2d43e 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestExistsBuilder.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestExistsBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.apache.zookeeper.ZooDefs.Ids.ANYONE_ID_UNSAFE;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFailedDeleteManager.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFailedDeleteManager.java
index 4ce804a4..8b87f8e8 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFailedDeleteManager.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFailedDeleteManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertFalse;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFramework.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFramework.java
index 3e5b94a7..5c285fbe 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFramework.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkBackground.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkBackground.java
index bbf052e4..00f2dff6 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkBackground.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkBackground.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkEdges.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkEdges.java
index 3ddae4df..f0c91263 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkEdges.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestFrameworkEdges.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestGzipCompressionProvider.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestGzipCompressionProvider.java
index 78c0bb2b..67e0bbc9 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestGzipCompressionProvider.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestGzipCompressionProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestMultiClient.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestMultiClient.java
index f4e0fdf0..a2cdaa9b 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestMultiClient.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestMultiClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNamespaceFacade.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNamespaceFacade.java
index cd33cb64..69aa9e4c 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNamespaceFacade.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNamespaceFacade.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNeverConnected.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNeverConnected.java
index 64ba576f..cd85bd9f 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNeverConnected.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestNeverConnected.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReadOnly.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReadOnly.java
index 1d1d2d04..be0c312f 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReadOnly.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReadOnly.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReconfiguration.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReconfiguration.java
index ed58dac7..c4b10616 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReconfiguration.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestReconfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestSetData.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestSetData.java
index 742cf675..0d526e20 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestSetData.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestSetData.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.apache.zookeeper.KeeperException.Code.*;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTempFramework.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTempFramework.java
index f17ee7c4..717c2d2f 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTempFramework.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTempFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsNew.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsNew.java
index c4144f01..02b7c729 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsNew.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsNew.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsOld.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsOld.java
index 7fd3f53a..d157d28a 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsOld.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTransactionsOld.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTtlNodes.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTtlNodes.java
index c00ab0ed..c4c82dbf 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTtlNodes.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestTtlNodes.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertNull;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherIdentity.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherIdentity.java
index 70e99ca6..07beb6e8 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherIdentity.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherIdentity.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import com.google.common.collect.Sets;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherRemovalManager.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherRemovalManager.java
index c6ac16cd..9113d5aa 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherRemovalManager.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatcherRemovalManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatchesBuilder.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatchesBuilder.java
index 30526506..949cb12a 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatchesBuilder.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWatchesBuilder.java
@@ -1,21 +1,22 @@
-/**
- * Licensed 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 licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/*
+ * Licensed 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 licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWithCluster.java b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWithCluster.java
index 4784af1d..ee6149be 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWithCluster.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/imps/TestWithCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.imps;
 
 import static org.junit.jupiter.api.Assertions.assertNotNull;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/schema/TestSchema.java b/curator-framework/src/test/java/org/apache/curator/framework/schema/TestSchema.java
index 9454ef56..60ab0580 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/schema/TestSchema.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/schema/TestSchema.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.schema;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreaker.java b/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreaker.java
index f6cd3995..12ccfb79 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreaker.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreaker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreakingConnectionStateListener.java b/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreakingConnectionStateListener.java
index 61c8da8a..84aba9c5 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreakingConnectionStateListener.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/state/TestCircuitBreakingConnectionStateListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/java/org/apache/curator/framework/state/TestConnectionStateManager.java b/curator-framework/src/test/java/org/apache/curator/framework/state/TestConnectionStateManager.java
index 3c537cf7..0f53ce2f 100644
--- a/curator-framework/src/test/java/org/apache/curator/framework/state/TestConnectionStateManager.java
+++ b/curator-framework/src/test/java/org/apache/curator/framework/state/TestConnectionStateManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.state;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-framework/src/test/resources/log4j.properties b/curator-framework/src/test/resources/log4j.properties
index 2a85e0d1..706484ce 100644
--- a/curator-framework/src/test/resources/log4j.properties
+++ b/curator-framework/src/test/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-recipes/pom.xml b/curator-recipes/pom.xml
index 4aa7dbb1..d2750165 100644
--- a/curator-recipes/pom.xml
+++ b/curator-recipes/pom.xml
@@ -1,5 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -16,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 https://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/AfterConnectionEstablished.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/AfterConnectionEstablished.java
index 64ee4494..3ffdd7d8 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/AfterConnectionEstablished.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/AfterConnectionEstablished.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicStats.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicStats.java
index 2f66bee3..f290b371 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicStats.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicStats.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicValue.java
index a5d7adb4..7b7d2182 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/AtomicValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicInteger.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicInteger.java
index e55e48d3..0400e5bd 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicInteger.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicInteger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicLong.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicLong.java
index 22f27490..a03b0f11 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicLong.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/CachedAtomicLong.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicInteger.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicInteger.java
index 8c167c9a..7ea134b3 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicInteger.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicInteger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicLong.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicLong.java
index 9ee5b273..16f08603 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicLong.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicLong.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicNumber.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicNumber.java
index 0039a138..c2f81552 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicNumber.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicNumber.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicValue.java
index bbd9203d..d6ee901c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/DistributedAtomicValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import org.apache.curator.RetryLoop;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MakeValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MakeValue.java
index e9abf95a..d9c3edf6 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MakeValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MakeValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 interface MakeValue
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MutableAtomicValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MutableAtomicValue.java
index e6c968e1..8150ad8f 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MutableAtomicValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/MutableAtomicValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 class MutableAtomicValue<T> implements AtomicValue<T>
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/PromotedToLock.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/PromotedToLock.java
index caad66e3..4b631c4e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/PromotedToLock.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/atomic/PromotedToLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedBarrier.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedBarrier.java
index fb00ed9a..7fd382e7 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedBarrier.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedBarrier.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.barriers;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedDoubleBarrier.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedDoubleBarrier.java
index e6b300fc..059ab06e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedDoubleBarrier.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/barriers/DistributedDoubleBarrier.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.barriers;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/ChildData.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/ChildData.java
index e3c60cff..533a24a5 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/ChildData.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/ChildData.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.zookeeper.data.Stat;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CompatibleCuratorCacheBridge.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CompatibleCuratorCacheBridge.java
index 97293f24..2f83f59c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CompatibleCuratorCacheBridge.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CompatibleCuratorCacheBridge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import com.google.common.collect.Sets;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCache.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCache.java
index 8005f030..36fbd9b8 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCache.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheAccessor.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheAccessor.java
index a94e7149..7a7480df 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheAccessor.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheAccessor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridge.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridge.java
index b6ef9b9e..2bd6c152 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridge.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilder.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilder.java
index f84f56c2..d424fcbd 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilder.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilderImpl.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilderImpl.java
index 054c0ba9..9b439c22 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilderImpl.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBridgeBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilder.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilder.java
index efc36caf..23eb3944 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilder.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilderImpl.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilderImpl.java
index 1386b4f0..4821166b 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilderImpl.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheImpl.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheImpl.java
index 4f31e0e2..c45887a6 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheImpl.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListener.java
index 620e4714..850058a5 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilder.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilder.java
index 08f53dc7..a1157851 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilder.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilderImpl.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilderImpl.java
index 2ca88159..2414f3d6 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilderImpl.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheListenerBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheStorage.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheStorage.java
index 7540b562..f2b0525d 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheStorage.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/CuratorCacheStorage.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import java.util.Optional;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/DefaultTreeCacheSelector.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/DefaultTreeCacheSelector.java
index 822f0987..4bb0d321 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/DefaultTreeCacheSelector.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/DefaultTreeCacheSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/EventOperation.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/EventOperation.java
index 64ee7911..431b781d 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/EventOperation.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/EventOperation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 class EventOperation implements Operation
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/GetDataOperation.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/GetDataOperation.java
index f789d10d..adcb2cca 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/GetDataOperation.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/GetDataOperation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.utils.PathUtils;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCache.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCache.java
index 11653f8c..c0db271c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCache.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListener.java
index 304974b9..78e28b23 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 public interface NodeCacheListener
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListenerWrapper.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListenerWrapper.java
index 468049ba..e6fd355f 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListenerWrapper.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/NodeCacheListenerWrapper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/Operation.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/Operation.java
index eea7f245..ff262619 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/Operation.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/Operation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 interface Operation
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCache.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCache.java
index 9121a49f..9ef9f048 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCache.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheEvent.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheEvent.java
index f1c10f89..8d7fb868 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheEvent.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheEvent.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.state.ConnectionState;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListener.java
index 0b3e14bf..0e8a3092 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListenerWrapper.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListenerWrapper.java
index 5bfc20df..ebfb2fc2 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListenerWrapper.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheListenerWrapper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheMode.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheMode.java
index 5c15fda4..06aead1c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheMode.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/PathChildrenCacheMode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/RefreshOperation.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/RefreshOperation.java
index aed82e09..6ea443aa 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/RefreshOperation.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/RefreshOperation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 class RefreshOperation implements Operation
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/StandardCuratorCacheStorage.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/StandardCuratorCacheStorage.java
index bed60b55..5eb4cc6e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/StandardCuratorCacheStorage.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/StandardCuratorCacheStorage.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCache.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCache.java
index 5e7deb76..91ae7531 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCache.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheEvent.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheEvent.java
index 012b2808..e421e0dd 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheEvent.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheEvent.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheIterator.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheIterator.java
index eed42dc7..89ae2e54 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheIterator.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheIterator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import com.google.common.collect.Iterators;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListener.java
index 6ea342dd..79b2bf84 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListenerWrapper.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListenerWrapper.java
index 9c99f691..7183c3bb 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListenerWrapper.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheListenerWrapper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheSelector.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheSelector.java
index 5d98ad97..f65a2f70 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheSelector.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/cache/TreeCacheSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/CancelLeadershipException.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/CancelLeadershipException.java
index 73e3c85d..246c988c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/CancelLeadershipException.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/CancelLeadershipException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatch.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatch.java
index 553e5070..800cfec9 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatch.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatch.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatchListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatchListener.java
index 68dd355a..c994fa72 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatchListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderLatchListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelector.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelector.java
index 4d00c4ce..854385aa 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelector.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListener.java
index fabdded5..cb3ecdf0 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListenerAdapter.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListenerAdapter.java
index 19c0e928..bed177c2 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListenerAdapter.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/LeaderSelectorListenerAdapter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/Participant.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/Participant.java
index e13f819b..5ac7ef2e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/Participant.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/leader/Participant.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessLock.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessLock.java
index 2f7a81a4..c08a3119 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessLock.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import java.util.concurrent.TimeUnit;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMultiLock.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMultiLock.java
index 904d338c..6ec28d8a 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMultiLock.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMultiLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import com.google.common.collect.ImmutableList;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMutex.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMutex.java
index 77ef6854..66c61c6e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMutex.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessMutex.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessReadWriteLock.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessReadWriteLock.java
index e4376a54..53718eb5 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessReadWriteLock.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessReadWriteLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import com.google.common.base.Predicate;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphore.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphore.java
index 2e6db02a..546260bd 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphore.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreMutex.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreMutex.java
index 8d578bd8..dc965e56 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreMutex.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreMutex.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreV2.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreV2.java
index 6404888e..6376b37c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreV2.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/InterProcessSemaphoreV2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Lease.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Lease.java
index c99f51ec..62e47369 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Lease.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Lease.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import java.io.Closeable;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternals.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternals.java
index a22bfb10..bc6475b4 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternals.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternals.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import com.google.common.base.Function;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsDriver.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsDriver.java
index 69e3ce6c..158956c4 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsDriver.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsSorter.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsSorter.java
index 38175b7e..71eab0ce 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsSorter.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/LockInternalsSorter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 public interface LockInternalsSorter
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Locker.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Locker.java
index 2644a8d8..6b356f6a 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Locker.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Locker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import java.util.concurrent.TimeUnit;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/PredicateResults.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/PredicateResults.java
index b032d981..fe9f2a5e 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/PredicateResults.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/PredicateResults.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 public class PredicateResults
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revocable.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revocable.java
index df0c372a..e5df55bb 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revocable.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revocable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import java.util.concurrent.Executor;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationListener.java
index e6038458..cebf7458 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 public interface RevocationListener<T>
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationSpec.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationSpec.java
index ca823dcf..f1cf7e91 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationSpec.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/RevocationSpec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import java.util.concurrent.Executor;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revoker.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revoker.java
index 4c077da9..da412fff 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revoker.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/Revoker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/StandardLockInternalsDriver.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/StandardLockInternalsDriver.java
index 43184f5d..2d785b92 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/StandardLockInternalsDriver.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/locks/StandardLockInternalsDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/GroupMember.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/GroupMember.java
index 681e3fd3..91b501ea 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/GroupMember.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/GroupMember.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentEphemeralNode.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentEphemeralNode.java
index 5576dc2c..1b60a715 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentEphemeralNode.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentEphemeralNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNode.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNode.java
index 72db4540..aa2f1a6f 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNode.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNodeListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNodeListener.java
index 4131140e..79b73469 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNodeListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentNodeListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentTtlNode.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentTtlNode.java
index 6a0f15b6..4d21fbe7 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentTtlNode.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/nodes/PersistentTtlNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/BlockingQueueConsumer.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/BlockingQueueConsumer.java
index 24598616..fdba44e4 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/BlockingQueueConsumer.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/BlockingQueueConsumer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.collect.ImmutableList;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ChildrenCache.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ChildrenCache.java
index a28a1cc8..7e46370b 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ChildrenCache.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ChildrenCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.collect.ImmutableList;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedDelayQueue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedDelayQueue.java
index 5327a094..9c273c6d 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedDelayQueue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedDelayQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedIdQueue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedIdQueue.java
index 45b84c43..ecf743c0 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedIdQueue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedIdQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedPriorityQueue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedPriorityQueue.java
index be61de25..240351b6 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedPriorityQueue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedPriorityQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedQueue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedQueue.java
index 0df2930d..f18a88d0 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedQueue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/DistributedQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ErrorMode.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ErrorMode.java
index 2cd558ef..9610baef 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ErrorMode.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ErrorMode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ItemSerializer.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ItemSerializer.java
index af802965..4b519cf2 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ItemSerializer.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/ItemSerializer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.collect.Lists;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/MultiItem.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/MultiItem.java
index 2d2d1342..eb8433fe 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/MultiItem.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/MultiItem.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueAllocator.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueAllocator.java
index 255b764d..60fc69bd 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueAllocator.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueAllocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBase.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBase.java
index f9fee137..1a24c5a9 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBase.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import org.apache.curator.framework.listen.Listenable;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBuilder.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBuilder.java
index 39ba192d..ba8043a3 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBuilder.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueConsumer.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueConsumer.java
index aa75dbd3..ad5d6c8d 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueConsumer.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueConsumer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import org.apache.curator.framework.state.ConnectionStateListener;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueuePutListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueuePutListener.java
index d8fd80d9..b8548698 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueuePutListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueuePutListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSafety.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSafety.java
index 3de5ba50..350b8062 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSafety.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSafety.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import java.util.concurrent.BlockingQueue;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSerializer.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSerializer.java
index c7c6c9ad..ad65ddb5 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSerializer.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSerializer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 /**
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharder.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharder.java
index 32470e4b..47c77de9 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharder.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharderPolicies.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharderPolicies.java
index 5f2dfc63..db093d73 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharderPolicies.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/QueueSharderPolicies.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/SimpleDistributedQueue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/SimpleDistributedQueue.java
index 3ee71303..421b08c4 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/SimpleDistributedQueue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/queue/SimpleDistributedQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCount.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCount.java
index 8ae90725..5dcf63af 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCount.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCount.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import com.google.common.annotations.VisibleForTesting;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountListener.java
index ba4aa247..950f5beb 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import org.apache.curator.framework.state.ConnectionStateListener;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountReader.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountReader.java
index cae31bb3..d87babd4 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountReader.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedCountReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import org.apache.curator.framework.listen.Listenable;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValue.java
index d6052344..d5f971fb 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueListener.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueListener.java
index 50b9e13e..5dc32384 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueListener.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import org.apache.curator.framework.state.ConnectionStateListener;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueReader.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueReader.java
index a846c549..1fdc564d 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueReader.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/SharedValueReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import org.apache.curator.framework.listen.Listenable;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/VersionedValue.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/VersionedValue.java
index a3c15ab0..323709f1 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/VersionedValue.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/shared/VersionedValue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.shared;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/watch/PersistentWatcher.java b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/watch/PersistentWatcher.java
index 3b70b2f5..9577be3c 100644
--- a/curator-recipes/src/main/java/org/apache/curator/framework/recipes/watch/PersistentWatcher.java
+++ b/curator-recipes/src/main/java/org/apache/curator/framework/recipes/watch/PersistentWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 /**
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
diff --git a/curator-recipes/src/test/java/org/apache/curator/connection/TestThreadLocalRetryLoop.java b/curator-recipes/src/test/java/org/apache/curator/connection/TestThreadLocalRetryLoop.java
index 11a5af5b..dbce038d 100644
--- a/curator-recipes/src/test/java/org/apache/curator/connection/TestThreadLocalRetryLoop.java
+++ b/curator-recipes/src/test/java/org/apache/curator/connection/TestThreadLocalRetryLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.connection;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/client/TestBackgroundStates.java b/curator-recipes/src/test/java/org/apache/curator/framework/client/TestBackgroundStates.java
index cf90a677..54c482ed 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/client/TestBackgroundStates.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/client/TestBackgroundStates.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/client/TestResetConnectionWithBackgroundFailure.java b/curator-recipes/src/test/java/org/apache/curator/framework/client/TestResetConnectionWithBackgroundFailure.java
index 7bcd93a7..074aa4a4 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/client/TestResetConnectionWithBackgroundFailure.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/client/TestResetConnectionWithBackgroundFailure.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestCachedAtomicCounter.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestCachedAtomicCounter.java
index 28813fe8..facf058d 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestCachedAtomicCounter.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestCachedAtomicCounter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestDistributedAtomicLong.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestDistributedAtomicLong.java
index 1cd0f965..d5c83b3c 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestDistributedAtomicLong.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/atomic/TestDistributedAtomicLong.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.atomic;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedBarrier.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedBarrier.java
index f43a943e..06de22a9 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedBarrier.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedBarrier.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.barriers;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedDoubleBarrier.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedDoubleBarrier.java
index aa4aaa62..a8546cb2 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedDoubleBarrier.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/barriers/TestDistributedDoubleBarrier.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.barriers;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/BaseTestTreeCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/BaseTestTreeCache.java
index 2a5adf6f..8ab8f77a 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/BaseTestTreeCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/BaseTestTreeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCache.java
index 26672131..b8a4b28d 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheBridge.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheBridge.java
index 1c0f8cdc..69b00627 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheBridge.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheBridge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheConsistency.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheConsistency.java
index 2f9eb52d..f9ae96ea 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheConsistency.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheConsistency.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEdges.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEdges.java
index ba588aff..9c8f2882 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEdges.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEdges.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEventOrdering.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEventOrdering.java
index d2121163..18a0fc97 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEventOrdering.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheEventOrdering.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheWrappers.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheWrappers.java
index 056e9cc8..0e44d341 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheWrappers.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestCuratorCacheWrappers.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestEventOrdering.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestEventOrdering.java
index d039fa1c..473171d9 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestEventOrdering.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestEventOrdering.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestNodeCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestNodeCache.java
index 28a53daf..21b3ee15 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestNodeCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestNodeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCache.java
index 72ef2725..283bb18a 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheEventOrdering.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheEventOrdering.java
index 31b0fc7b..b69265a6 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheEventOrdering.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheEventOrdering.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheInCluster.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheInCluster.java
index 3b90254f..e0576144 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheInCluster.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestPathChildrenCacheInCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCache.java
index 2b9e491c..354e3b22 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheEventOrdering.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheEventOrdering.java
index fd3a2acf..dca301d3 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheEventOrdering.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheEventOrdering.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheIteratorAndSize.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheIteratorAndSize.java
index a0daae32..99695fb4 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheIteratorAndSize.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheIteratorAndSize.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheRandomTree.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheRandomTree.java
index 687f027c..9a63b57f 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheRandomTree.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestTreeCacheRandomTree.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestWrappedNodeCache.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestWrappedNodeCache.java
index 26aa64e2..0e8b1a0d 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestWrappedNodeCache.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/cache/TestWrappedNodeCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.cache;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/ChaosMonkeyCnxnFactory.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/ChaosMonkeyCnxnFactory.java
index aaaf43c1..50d51a36 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/ChaosMonkeyCnxnFactory.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/ChaosMonkeyCnxnFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderAcls.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderAcls.java
index 4d1172c5..3df80bcb 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderAcls.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderAcls.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatch.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatch.java
index 69deb207..0c8bdbad 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatch.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatch.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatchCluster.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatchCluster.java
index 5fba3b1a..7692d7b1 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatchCluster.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderLatchCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelector.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelector.java
index 541f4c5c..e8a980c9 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelector.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorCluster.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorCluster.java
index 10903ed2..278f6c0f 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorCluster.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import static org.junit.jupiter.api.Assertions.assertFalse;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorEdges.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorEdges.java
index 003f383a..331ac49c 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorEdges.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorEdges.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorParticipants.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorParticipants.java
index d80b93f1..34b62ba2 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorParticipants.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorParticipants.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorWithExecutor.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorWithExecutor.java
index cd77f18a..f0673c92 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorWithExecutor.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/leader/TestLeaderSelectorWithExecutor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.leader;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Counter.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Counter.java
index 414a1e2b..0c03fa43 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Counter.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/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
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 class Counter
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/SemaphoreClient.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/SemaphoreClient.java
index 985e6303..948ed946 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/SemaphoreClient.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/SemaphoreClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import org.apache.curator.utils.CloseableUtils;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Stepper.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Stepper.java
index ca48036b..a6c5c205 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Stepper.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/Stepper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 class Stepper
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMultiMutex.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMultiMutex.java
index faf0f7f6..d353a57e 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMultiMutex.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMultiMutex.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import static org.junit.jupiter.api.Assertions.assertFalse;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutex.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutex.java
index b5c30ae1..2a15a5f7 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutex.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutex.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutexBase.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutexBase.java
index 3a25e288..6dfe4c92 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutexBase.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessMutexBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessReadWriteLock.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessReadWriteLock.java
index f248e8d8..a54bd401 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessReadWriteLock.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessReadWriteLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphore.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphore.java
index edd649b0..9cba32d3 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphore.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreCluster.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreCluster.java
index 01bd3329..4a5c2749 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreCluster.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreMutex.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreMutex.java
index d81d7936..8ea5699b 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreMutex.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestInterProcessSemaphoreMutex.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockACLs.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockACLs.java
index f110a97d..9eaec0d3 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockACLs.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockACLs.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockCleanlinessWithFaults.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockCleanlinessWithFaults.java
index d73e73c6..31f15d3b 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockCleanlinessWithFaults.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/locks/TestLockCleanlinessWithFaults.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.locks;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestGroupMember.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestGroupMember.java
index 560ea424..cf79fae2 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestGroupMember.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestGroupMember.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNode.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNode.java
index 7e4835d6..88d98700 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNode.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNodeListener.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNodeListener.java
index 6a411af0..b114dc3a 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNodeListener.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentEphemeralNodeListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentNode.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentNode.java
index 5ec20dad..5f136d12 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentNode.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import static org.junit.jupiter.api.Assertions.assertArrayEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentTtlNode.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentTtlNode.java
index 96d51383..60a0623f 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentTtlNode.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/nodes/TestPersistentTtlNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.nodes;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueItemSerializer.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueItemSerializer.java
index ea16d0b0..3d34f84a 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueItemSerializer.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueItemSerializer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 class QueueItemSerializer implements QueueSerializer<TestQueueItem>
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueTestProducer.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueTestProducer.java
index 8c097c2e..2c36e400 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueTestProducer.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/QueueTestProducer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import java.util.concurrent.Callable;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestBoundedDistributedQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestBoundedDistributedQueue.java
index 9547d41f..c04c51a7 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestBoundedDistributedQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestBoundedDistributedQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedDelayQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedDelayQueue.java
index f130a30d..077e06df 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedDelayQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedDelayQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedIdQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedIdQueue.java
index c2a81ab1..dfa9775a 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedIdQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedIdQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedPriorityQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedPriorityQueue.java
index 59b1227d..f763f013 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedPriorityQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedPriorityQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedQueue.java
index e9f60140..3378333f 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestDistributedQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestLongNetworkPartition.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestLongNetworkPartition.java
index 2e3c7a5b..7d45b751 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestLongNetworkPartition.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestLongNetworkPartition.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import org.apache.curator.ensemble.fixed.FixedEnsembleProvider;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueItem.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueItem.java
index e6499cfd..82065ec4 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueItem.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueItem.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 class TestQueueItem implements Comparable<TestQueueItem>
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueSharder.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueSharder.java
index 8e250626..44004ad0 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueSharder.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestQueueSharder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestSimpleDistributedQueue.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestSimpleDistributedQueue.java
index 2b90449a..611db415 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestSimpleDistributedQueue.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/queue/TestSimpleDistributedQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework.recipes.queue;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/shared/TestSharedCount.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/shared/TestSharedCount.java
index cddefd52..4c974267 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/shared/TestSharedCount.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/shared/TestSharedCount.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/watch/TestPersistentWatcher.java b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/watch/TestPersistentWatcher.java
index d21f2bef..fd73de60 100644
--- a/curator-recipes/src/test/java/org/apache/curator/framework/recipes/watch/TestPersistentWatcher.java
+++ b/curator-recipes/src/test/java/org/apache/curator/framework/recipes/watch/TestPersistentWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-recipes/src/test/resources/log4j.properties b/curator-recipes/src/test/resources/log4j.properties
index 2a85e0d1..706484ce 100644
--- a/curator-recipes/src/test/resources/log4j.properties
+++ b/curator-recipes/src/test/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-test-zk35/pom.xml b/curator-test-zk35/pom.xml
index d0f9b7e6..94987a74 100644
--- a/curator-test-zk35/pom.xml
+++ b/curator-test-zk35/pom.xml
@@ -1,4 +1,6 @@
-<?xml version="1.0" encoding="UTF-8"?><!--
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -15,7 +17,9 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <groupId>org.apache.curator</groupId>
diff --git a/curator-test-zk35/src/test/java/org/apache/curator/framework/TestCompatibility.java b/curator-test-zk35/src/test/java/org/apache/curator/framework/TestCompatibility.java
index 2a249e08..5434c1b8 100644
--- a/curator-test-zk35/src/test/java/org/apache/curator/framework/TestCompatibility.java
+++ b/curator-test-zk35/src/test/java/org/apache/curator/framework/TestCompatibility.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.framework;
 
 import static org.junit.jupiter.api.Assertions.assertThrows;
diff --git a/curator-test-zk35/src/test/java/org/apache/curator/zk35/TestIs35.java b/curator-test-zk35/src/test/java/org/apache/curator/zk35/TestIs35.java
index acc1ab0b..283f1f89 100644
--- a/curator-test-zk35/src/test/java/org/apache/curator/zk35/TestIs35.java
+++ b/curator-test-zk35/src/test/java/org/apache/curator/zk35/TestIs35.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.zk35;
 
 import static org.junit.jupiter.api.Assertions.assertFalse;
diff --git a/curator-test-zk35/src/test/resources/log4j.properties b/curator-test-zk35/src/test/resources/log4j.properties
index 2a85e0d1..706484ce 100644
--- a/curator-test-zk35/src/test/resources/log4j.properties
+++ b/curator-test-zk35/src/test/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-test-zk36/pom.xml b/curator-test-zk36/pom.xml
index 2b293728..61e90c51 100644
--- a/curator-test-zk36/pom.xml
+++ b/curator-test-zk36/pom.xml
@@ -1,4 +1,6 @@
-<?xml version="1.0" encoding="UTF-8"?><!--
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -15,7 +17,9 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <groupId>org.apache.curator</groupId>
diff --git a/curator-test-zk36/src/test/java/org/apache/curator/zk36/TestIs36.java b/curator-test-zk36/src/test/java/org/apache/curator/zk36/TestIs36.java
index f5d062f9..bfe7b248 100644
--- a/curator-test-zk36/src/test/java/org/apache/curator/zk36/TestIs36.java
+++ b/curator-test-zk36/src/test/java/org/apache/curator/zk36/TestIs36.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.zk36;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
diff --git a/curator-test-zk36/src/test/resources/log4j.properties b/curator-test-zk36/src/test/resources/log4j.properties
index 2a85e0d1..706484ce 100644
--- a/curator-test-zk36/src/test/resources/log4j.properties
+++ b/curator-test-zk36/src/test/resources/log4j.properties
@@ -1,4 +1,3 @@
-#
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
 # distributed with this work for additional information
@@ -15,7 +14,6 @@
 # KIND, either express or implied.  See the License for the
 # specific language governing permissions and limitations
 # under the License.
-#
 
 log4j.rootLogger=ERROR, console
 
diff --git a/curator-test/pom.xml b/curator-test/pom.xml
index 4417b2b5..dd9cb4be 100644
--- a/curator-test/pom.xml
+++ b/curator-test/pom.xml
@@ -1,5 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -16,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 https://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
diff --git a/curator-test/src/main/java/org/apache/curator/test/BaseClassForTests.java b/curator-test/src/main/java/org/apache/curator/test/BaseClassForTests.java
index 1ed3500b..feb3c3dc 100644
--- a/curator-test/src/main/java/org/apache/curator/test/BaseClassForTests.java
+++ b/curator-test/src/main/java/org/apache/curator/test/BaseClassForTests.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/Compatibility.java b/curator-test/src/main/java/org/apache/curator/test/Compatibility.java
index b3d79261..804a5c38 100644
--- a/curator-test/src/main/java/org/apache/curator/test/Compatibility.java
+++ b/curator-test/src/main/java/org/apache/curator/test/Compatibility.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import org.apache.zookeeper.server.ServerCnxn;
diff --git a/curator-test/src/main/java/org/apache/curator/test/DelegatingExecutorService.java b/curator-test/src/main/java/org/apache/curator/test/DelegatingExecutorService.java
index eff34dde..96b3167d 100644
--- a/curator-test/src/main/java/org/apache/curator/test/DelegatingExecutorService.java
+++ b/curator-test/src/main/java/org/apache/curator/test/DelegatingExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import java.util.Collection;
diff --git a/curator-test/src/main/java/org/apache/curator/test/DirectoryUtils.java b/curator-test/src/main/java/org/apache/curator/test/DirectoryUtils.java
index 8c4c8d88..2c7c1410 100644
--- a/curator-test/src/main/java/org/apache/curator/test/DirectoryUtils.java
+++ b/curator-test/src/main/java/org/apache/curator/test/DirectoryUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-test/src/main/java/org/apache/curator/test/ExecuteCalledWatchingExecutorService.java b/curator-test/src/main/java/org/apache/curator/test/ExecuteCalledWatchingExecutorService.java
index da7bc665..0bdb4485 100644
--- a/curator-test/src/main/java/org/apache/curator/test/ExecuteCalledWatchingExecutorService.java
+++ b/curator-test/src/main/java/org/apache/curator/test/ExecuteCalledWatchingExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import java.util.concurrent.ExecutorService;
diff --git a/curator-test/src/main/java/org/apache/curator/test/FailedServerStartException.java b/curator-test/src/main/java/org/apache/curator/test/FailedServerStartException.java
index 81b87e08..0c7db370 100644
--- a/curator-test/src/main/java/org/apache/curator/test/FailedServerStartException.java
+++ b/curator-test/src/main/java/org/apache/curator/test/FailedServerStartException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 public class FailedServerStartException extends IllegalStateException
diff --git a/curator-test/src/main/java/org/apache/curator/test/InstanceSpec.java b/curator-test/src/main/java/org/apache/curator/test/InstanceSpec.java
index 375d8801..02373164 100644
--- a/curator-test/src/main/java/org/apache/curator/test/InstanceSpec.java
+++ b/curator-test/src/main/java/org/apache/curator/test/InstanceSpec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/KillSession.java b/curator-test/src/main/java/org/apache/curator/test/KillSession.java
index ce2b7e60..684ca377 100644
--- a/curator-test/src/main/java/org/apache/curator/test/KillSession.java
+++ b/curator-test/src/main/java/org/apache/curator/test/KillSession.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import org.apache.zookeeper.ZooKeeper;
diff --git a/curator-test/src/main/java/org/apache/curator/test/QuorumConfigBuilder.java b/curator-test/src/main/java/org/apache/curator/test/QuorumConfigBuilder.java
index 35c3523e..5d22b746 100644
--- a/curator-test/src/main/java/org/apache/curator/test/QuorumConfigBuilder.java
+++ b/curator-test/src/main/java/org/apache/curator/test/QuorumConfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/QuorumPeerConfigBuilder.java b/curator-test/src/main/java/org/apache/curator/test/QuorumPeerConfigBuilder.java
index aef3b83a..8fce4718 100644
--- a/curator-test/src/main/java/org/apache/curator/test/QuorumPeerConfigBuilder.java
+++ b/curator-test/src/main/java/org/apache/curator/test/QuorumPeerConfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/ServerHelper.java b/curator-test/src/main/java/org/apache/curator/test/ServerHelper.java
index 5a9dff4b..4577b630 100644
--- a/curator-test/src/main/java/org/apache/curator/test/ServerHelper.java
+++ b/curator-test/src/main/java/org/apache/curator/test/ServerHelper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import org.apache.zookeeper.server.ZooKeeperServer;
diff --git a/curator-test/src/main/java/org/apache/curator/test/TestingCluster.java b/curator-test/src/main/java/org/apache/curator/test/TestingCluster.java
index 58da2c03..dc0dff1f 100644
--- a/curator-test/src/main/java/org/apache/curator/test/TestingCluster.java
+++ b/curator-test/src/main/java/org/apache/curator/test/TestingCluster.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import com.google.common.base.Function;
diff --git a/curator-test/src/main/java/org/apache/curator/test/TestingQuorumPeerMain.java b/curator-test/src/main/java/org/apache/curator/test/TestingQuorumPeerMain.java
index d237f356..de249729 100644
--- a/curator-test/src/main/java/org/apache/curator/test/TestingQuorumPeerMain.java
+++ b/curator-test/src/main/java/org/apache/curator/test/TestingQuorumPeerMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import java.lang.reflect.Field;
diff --git a/curator-test/src/main/java/org/apache/curator/test/TestingServer.java b/curator-test/src/main/java/org/apache/curator/test/TestingServer.java
index 4a50afcf..1309682d 100644
--- a/curator-test/src/main/java/org/apache/curator/test/TestingServer.java
+++ b/curator-test/src/main/java/org/apache/curator/test/TestingServer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperMain.java b/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperMain.java
index aa702e0c..ef014ca5 100644
--- a/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperMain.java
+++ b/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperMain.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperServer.java b/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperServer.java
index f12c117c..0df2a85a 100644
--- a/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperServer.java
+++ b/curator-test/src/main/java/org/apache/curator/test/TestingZooKeeperServer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/Timing.java b/curator-test/src/main/java/org/apache/curator/test/Timing.java
index f29b1c5e..23946830 100644
--- a/curator-test/src/main/java/org/apache/curator/test/Timing.java
+++ b/curator-test/src/main/java/org/apache/curator/test/Timing.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/WatchersDebug.java b/curator-test/src/main/java/org/apache/curator/test/WatchersDebug.java
index e4c3b7e7..c8d6b5c0 100644
--- a/curator-test/src/main/java/org/apache/curator/test/WatchersDebug.java
+++ b/curator-test/src/main/java/org/apache/curator/test/WatchersDebug.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import org.apache.zookeeper.ZooKeeper;
diff --git a/curator-test/src/main/java/org/apache/curator/test/ZooKeeperMainFace.java b/curator-test/src/main/java/org/apache/curator/test/ZooKeeperMainFace.java
index 6f812079..1e95d2ca 100644
--- a/curator-test/src/main/java/org/apache/curator/test/ZooKeeperMainFace.java
+++ b/curator-test/src/main/java/org/apache/curator/test/ZooKeeperMainFace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test;
 
 import java.io.Closeable;
diff --git a/curator-test/src/main/java/org/apache/curator/test/ZooKeeperServerEmbeddedAdapter.java b/curator-test/src/main/java/org/apache/curator/test/ZooKeeperServerEmbeddedAdapter.java
index ba7591bc..95ff863d 100644
--- a/curator-test/src/main/java/org/apache/curator/test/ZooKeeperServerEmbeddedAdapter.java
+++ b/curator-test/src/main/java/org/apache/curator/test/ZooKeeperServerEmbeddedAdapter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/main/java/org/apache/curator/test/compatibility/CuratorTestBase.java b/curator-test/src/main/java/org/apache/curator/test/compatibility/CuratorTestBase.java
index 1fcd0d0e..a7b846fd 100644
--- a/curator-test/src/main/java/org/apache/curator/test/compatibility/CuratorTestBase.java
+++ b/curator-test/src/main/java/org/apache/curator/test/compatibility/CuratorTestBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.test.compatibility;
 
 import org.apache.curator.test.BaseClassForTests;
diff --git a/curator-test/src/main/java/org/apache/curator/test/compatibility/Timing2.java b/curator-test/src/main/java/org/apache/curator/test/compatibility/Timing2.java
index f9ee75b7..d8fe1537 100644
--- a/curator-test/src/main/java/org/apache/curator/test/compatibility/Timing2.java
+++ b/curator-test/src/main/java/org/apache/curator/test/compatibility/Timing2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-test/src/test/java/org/apache/curator/test/TestQuorumConfigBuilder.java b/curator-test/src/test/java/org/apache/curator/test/TestQuorumConfigBuilder.java
index 3737f821..f75727a9 100644
--- a/curator-test/src/test/java/org/apache/curator/test/TestQuorumConfigBuilder.java
+++ b/curator-test/src/test/java/org/apache/curator/test/TestQuorumConfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -17,7 +17,6 @@
  * under the License.
  */
 
-
 package org.apache.curator.test;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-test/src/test/java/org/apache/curator/test/TestTestingServer.java b/curator-test/src/test/java/org/apache/curator/test/TestTestingServer.java
index 09ac4470..40291aed 100644
--- a/curator-test/src/test/java/org/apache/curator/test/TestTestingServer.java
+++ b/curator-test/src/test/java/org/apache/curator/test/TestTestingServer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -17,7 +17,6 @@
  * under the License.
  */
 
-
 package org.apache.curator.test;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
diff --git a/curator-x-async/pom.xml b/curator-x-async/pom.xml
index 184e909c..810144ef 100644
--- a/curator-x-async/pom.xml
+++ b/curator-x-async/pom.xml
@@ -1,5 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
+
     Licensed to the Apache Software Foundation (ASF) under one
     or more contributor license agreements.  See the NOTICE file
     distributed with this work for additional information
@@ -16,7 +17,8 @@
     KIND, either express or implied.  See the License for the
     specific language governing permissions and limitations
     under the License.
-  -->
+
+-->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncCuratorFramework.java b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncCuratorFramework.java
index b8de84a5..5c91e928 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncCuratorFramework.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncCuratorFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 import org.apache.curator.framework.CuratorFramework;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncEventException.java b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncEventException.java
index f863215d..4e77e20a 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncEventException.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncEventException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 import org.apache.zookeeper.WatchedEvent;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncResult.java b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncResult.java
index c2642699..27bb468c 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncResult.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncResult.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 import org.apache.curator.x.async.details.AsyncResultImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncStage.java b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncStage.java
index ad7547bb..58601685 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncStage.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncStage.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 import org.apache.zookeeper.WatchedEvent;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncWrappers.java b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncWrappers.java
index f26b3b42..160eb3d7 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncWrappers.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/AsyncWrappers.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 import com.google.common.base.Throwables;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/WatchMode.java b/curator-x-async/src/main/java/org/apache/curator/x/async/WatchMode.java
index 13395e9a..e2c22fa3 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/WatchMode.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/WatchMode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async;
 
 public enum WatchMode
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCreateBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCreateBuilder.java
index 7ed934ea..da19ddb1 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCreateBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCreateBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCuratorFrameworkDsl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCuratorFrameworkDsl.java
index 09198612..b0fa01f0 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCuratorFrameworkDsl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncCuratorFrameworkDsl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncDeleteBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncDeleteBuilder.java
index 0258167c..f2254498 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncDeleteBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncDeleteBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncEnsemblable.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncEnsemblable.java
index a4b0d330..b95c6e31 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncEnsemblable.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncEnsemblable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncExistsBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncExistsBuilder.java
index 6174c7af..acb16f4c 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncExistsBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncExistsBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetACLBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetACLBuilder.java
index be93eafe..6da26c7f 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetACLBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetACLBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetChildrenBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetChildrenBuilder.java
index 4e3d8dbb..fa4b715f 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetChildrenBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetChildrenBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetConfigBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetConfigBuilder.java
index 94b0e975..a2887a63 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetConfigBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetConfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetDataBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetDataBuilder.java
index caa90cb7..ee5b2399 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetDataBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncGetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncMultiTransaction.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncMultiTransaction.java
index b972141e..fd6cad7a 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncMultiTransaction.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncMultiTransaction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathAndBytesable.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathAndBytesable.java
index c34b1ecd..2a9f3a4e 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathAndBytesable.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathAndBytesable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathable.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathable.java
index fbcba482..41b9d560 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathable.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncPathable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncReconfigBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncReconfigBuilder.java
index a5b52554..8fd192f2 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncReconfigBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncReconfigBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncRemoveWatchesBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncRemoveWatchesBuilder.java
index 3cd985f1..6bc1e6fe 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncRemoveWatchesBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncRemoveWatchesBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.CuratorWatcher;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetACLBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetACLBuilder.java
index 8503d2fd..a8d9e1a9 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetACLBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetACLBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetDataBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetDataBuilder.java
index 848d0ddb..2dd8b4de 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetDataBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSyncBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSyncBuilder.java
index d24ba5d9..e3bc0ebc 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSyncBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncSyncBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.x.async.AsyncStage;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCheckBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCheckBuilder.java
index 1e52fb48..af3de296 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCheckBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCheckBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCreateBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCreateBuilder.java
index 64b1c158..864eb124 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCreateBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionCreateBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionDeleteBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionDeleteBuilder.java
index 45b572f0..7210831d 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionDeleteBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionDeleteBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionOp.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionOp.java
index 2c0554b0..40e8e428 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionOp.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionSetDataBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionSetDataBuilder.java
index 7d41eb18..922256a1 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionSetDataBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncTransactionSetDataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 import org.apache.curator.framework.api.transaction.CuratorOp;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder.java
index 99e934c2..75108207 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder2.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder2.java
index b6cf2779..43a1e49d 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder2.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/AsyncWatchBuilder2.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/CreateOption.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/CreateOption.java
index c8d6db88..0b8f9cd6 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/CreateOption.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/CreateOption.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/DeleteOption.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/DeleteOption.java
index b5cc167c..2069fbe3 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/DeleteOption.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/DeleteOption.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/ExistsOption.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/ExistsOption.java
index 87490f0c..649db4a4 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/ExistsOption.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/ExistsOption.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/RemoveWatcherOption.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/RemoveWatcherOption.java
index e4f6add0..33696bbf 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/RemoveWatcherOption.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/RemoveWatcherOption.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/api/WatchableAsyncCuratorFramework.java b/curator-x-async/src/main/java/org/apache/curator/x/async/api/WatchableAsyncCuratorFramework.java
index 32db79a1..1e3642bc 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/api/WatchableAsyncCuratorFramework.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/api/WatchableAsyncCuratorFramework.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.api;
 
 /**
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCreateBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCreateBuilderImpl.java
index c27639e7..ec576b17 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCreateBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCreateBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CreateBuilderImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCuratorFrameworkImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCuratorFrameworkImpl.java
index a248c0e3..afeee947 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCuratorFrameworkImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncCuratorFrameworkImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import com.google.common.base.Preconditions;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncDeleteBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncDeleteBuilderImpl.java
index e9efb900..1f70ca73 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncDeleteBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncDeleteBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncExistsBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncExistsBuilderImpl.java
index 7a3385b3..057d7049 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncExistsBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncExistsBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetChildrenBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetChildrenBuilderImpl.java
index b98323f5..00516073 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetChildrenBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetChildrenBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetConfigBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetConfigBuilderImpl.java
index 62272a72..b67c1b26 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetConfigBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetConfigBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetDataBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetDataBuilderImpl.java
index deca49ab..ac179ba0 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetDataBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncGetDataBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncReconfigBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncReconfigBuilderImpl.java
index 61141599..7e989a9d 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncReconfigBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncReconfigBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncRemoveWatchesBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncRemoveWatchesBuilderImpl.java
index 1f3ad795..428eb98d 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncRemoveWatchesBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncRemoveWatchesBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.api.CuratorWatcher;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncResultImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncResultImpl.java
index c555b838..550ab407 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncResultImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncResultImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.x.async.AsyncResult;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetACLBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetACLBuilderImpl.java
index e639b9e7..583764a2 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetACLBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetACLBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetDataBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetDataBuilderImpl.java
index 750fd591..7f4a4cd5 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetDataBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncSetDataBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.CuratorFrameworkImpl;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncTransactionOpImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncTransactionOpImpl.java
index 2a2c293f..559572f2 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncTransactionOpImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncTransactionOpImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.api.ACLPathAndBytesable;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncWatchBuilderImpl.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncWatchBuilderImpl.java
index d6d37c1e..7e7b6b86 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncWatchBuilderImpl.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/AsyncWatchBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProc.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProc.java
index 9806566d..2a15dda9 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProc.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProc.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.api.CuratorEvent;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProcs.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProcs.java
index 944a82e0..a1a3975c 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProcs.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BackgroundProcs.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.api.CuratorEvent;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BuilderCommon.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BuilderCommon.java
index 82cd2447..bb0bb67e 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/BuilderCommon.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/BuilderCommon.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.imps.Backgrounding;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/Filters.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/Filters.java
index ab46590d..083866b7 100644
--- a/curator-x-async/src/main/java/org/apache/curator/x/async/details/Filters.java
+++ b/curator-x-async/src/main/java/org/apache/curator/x/async/details/Filters.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
@@ -16,6 +16,7 @@
  * specific language governing permissions and limitations
  * under the License.
  */
+
 package org.apache.curator.x.async.details;
 
 import org.apache.curator.framework.api.CuratorEvent;
diff --git a/curator-x-async/src/main/java/org/apache/curator/x/async/details/InternalCallback.java b/curator-x-async/src/main/java/org/apache/curator/x/async/details/InternalCallback.java
... 2749 lines suppressed ...