You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuweni.apache.org by to...@apache.org on 2019/04/23 23:08:45 UTC

[incubator-tuweni] 04/43: Change headers

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

toulmean pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-tuweni.git

commit b8d42bdf8eb5257a7dde201ee9af1c9abe2bf1ba
Author: Antoine Toulme <an...@lunar-ocean.com>
AuthorDate: Tue Apr 2 22:53:58 2019 -0700

    Change headers
---
 .../net/consensys/cava/bytes/AbstractBytes.java    |  8 ++++----
 .../consensys/cava/bytes/ArrayWrappingBytes.java   |  8 ++++----
 .../consensys/cava/bytes/ArrayWrappingBytes32.java |  8 ++++----
 .../consensys/cava/bytes/ArrayWrappingBytes48.java |  8 ++++----
 .../consensys/cava/bytes/BufferWrappingBytes.java  |  8 ++++----
 .../consensys/cava/bytes/ByteBufWrappingBytes.java |  8 ++++----
 .../cava/bytes/ByteBufferWrappingBytes.java        |  8 ++++----
 .../main/java/net/consensys/cava/bytes/Bytes.java  |  8 ++++----
 .../java/net/consensys/cava/bytes/Bytes32.java     |  8 ++++----
 .../java/net/consensys/cava/bytes/Bytes48.java     |  8 ++++----
 .../java/net/consensys/cava/bytes/BytesValues.java |  8 ++++----
 .../consensys/cava/bytes/ConcatenatedBytes.java    |  8 ++++----
 .../consensys/cava/bytes/DelegatingBytes32.java    |  8 ++++----
 .../consensys/cava/bytes/DelegatingBytes48.java    |  8 ++++----
 .../cava/bytes/DelegatingMutableBytes32.java       |  8 ++++----
 .../cava/bytes/DelegatingMutableBytes48.java       |  8 ++++----
 .../cava/bytes/MutableArrayWrappingBytes.java      |  8 ++++----
 .../cava/bytes/MutableArrayWrappingBytes32.java    |  8 ++++----
 .../cava/bytes/MutableArrayWrappingBytes48.java    |  8 ++++----
 .../cava/bytes/MutableBufferWrappingBytes.java     |  8 ++++----
 .../cava/bytes/MutableByteBufWrappingBytes.java    |  8 ++++----
 .../cava/bytes/MutableByteBufferWrappingBytes.java |  8 ++++----
 .../net/consensys/cava/bytes/MutableBytes.java     |  8 ++++----
 .../net/consensys/cava/bytes/MutableBytes32.java   |  8 ++++----
 .../net/consensys/cava/bytes/MutableBytes48.java   |  8 ++++----
 .../net/consensys/cava/bytes/BufferBytesTest.java  |  8 ++++----
 .../net/consensys/cava/bytes/ByteBufBytesTest.java |  8 ++++----
 .../consensys/cava/bytes/ByteBufferBytesTest.java  |  8 ++++----
 .../java/net/consensys/cava/bytes/Bytes32Test.java |  8 ++++----
 .../java/net/consensys/cava/bytes/Bytes48Test.java |  8 ++++----
 .../java/net/consensys/cava/bytes/BytesTest.java   |  8 ++++----
 .../net/consensys/cava/bytes/CommonBytesTests.java |  8 ++++----
 .../cava/bytes/ConcatenatedBytesTest.java          |  8 ++++----
 .../cava/concurrent/coroutines/AsyncCompletion.kt  | 20 ++++++++++++--------
 .../cava/concurrent/coroutines/AsyncResult.kt      | 20 ++++++++++++--------
 .../cava/concurrent/coroutines/CoroutineLatch.kt   | 20 ++++++++++++--------
 .../cava/concurrent/coroutines/Retryable.kt        | 20 ++++++++++++--------
 .../concurrent/coroutines/CoroutineLatchTest.kt    | 20 ++++++++++++--------
 .../cava/concurrent/coroutines/RetryableTest.kt    | 20 ++++++++++++--------
 .../consensys/cava/concurrent/AsyncCompletion.java |  8 ++++----
 .../net/consensys/cava/concurrent/AsyncResult.java |  8 ++++----
 .../consensys/cava/concurrent/AtomicSlotMap.java   |  8 ++++----
 .../concurrent/CompletableAsyncCompletion.java     |  8 ++++----
 .../cava/concurrent/CompletableAsyncResult.java    |  8 ++++----
 .../DefaultCompletableAsyncCompletion.java         |  8 ++++----
 .../concurrent/DefaultCompletableAsyncResult.java  |  8 ++++----
 .../net/consensys/cava/concurrent/ExpiringMap.java |  8 ++++----
 .../net/consensys/cava/concurrent/ExpiringSet.java |  8 ++++----
 .../cava/concurrent/AtomicSlotMapTest.java         |  8 ++++----
 .../DefaultCompletableAsyncCompletionTest.java     |  8 ++++----
 .../DefaultCompletableAsyncResultTest.java         |  8 ++++----
 .../consensys/cava/concurrent/ExpiringMapTest.java |  8 ++++----
 .../consensys/cava/concurrent/ExpiringSetTest.java |  8 ++++----
 .../net/consensys/cava/config/Configuration.java   |  8 ++++----
 .../consensys/cava/config/ConfigurationError.java  |  8 ++++----
 .../consensys/cava/config/ConfigurationErrors.java |  8 ++++----
 .../cava/config/ConfigurationValidator.java        |  8 ++++----
 .../consensys/cava/config/DocumentPosition.java    |  8 ++++----
 .../consensys/cava/config/EmptyConfiguration.java  |  8 ++++----
 .../InvalidConfigurationPropertyTypeException.java |  8 ++++----
 .../config/NoConfigurationPropertyException.java   |  8 ++++----
 .../consensys/cava/config/PropertyValidator.java   |  8 ++++----
 .../consensys/cava/config/PropertyValidators.java  |  8 ++++----
 .../java/net/consensys/cava/config/Schema.java     |  8 ++++----
 .../net/consensys/cava/config/SchemaBuilder.java   |  8 ++++----
 .../cava/config/TomlBackedConfiguration.java       |  8 ++++----
 .../net/consensys/cava/config/TomlSerializer.java  |  8 ++++----
 .../cava/config/PropertyValidatorTest.java         |  8 ++++----
 .../consensys/cava/config/SchemaBuilderTest.java   |  8 ++++----
 .../cava/config/TomlBackedConfigurationTest.java   |  8 ++++----
 .../main/java/net/consensys/cava/crypto/Hash.java  |  8 ++++----
 .../InvalidSEC256K1SecretKeyStoreException.java    |  8 ++++----
 .../java/net/consensys/cava/crypto/SECP256K1.java  |  8 ++++----
 .../consensys/cava/crypto/mikuli/AtePairing.java   |  8 ++++----
 .../net/consensys/cava/crypto/mikuli/BLS12381.java | 11 +++++------
 .../net/consensys/cava/crypto/mikuli/G1Point.java  | 13 ++++++-------
 .../net/consensys/cava/crypto/mikuli/G2Point.java  | 13 ++++++-------
 .../net/consensys/cava/crypto/mikuli/GTPoint.java  | 12 ++++++------
 .../net/consensys/cava/crypto/mikuli/Group.java    |  8 ++++----
 .../net/consensys/cava/crypto/mikuli/KeyPair.java  |  8 ++++----
 .../consensys/cava/crypto/mikuli/PublicKey.java    |  8 ++++----
 .../net/consensys/cava/crypto/mikuli/Scalar.java   | 12 ++++++------
 .../consensys/cava/crypto/mikuli/SecretKey.java    | 11 +++++------
 .../consensys/cava/crypto/mikuli/Signature.java    |  8 ++++----
 .../cava/crypto/mikuli/SignatureAndPublicKey.java  |  8 ++++----
 .../consensys/cava/crypto/sodium/AES256GCM.java    |  8 ++++----
 .../consensys/cava/crypto/sodium/Allocated.java    |  8 ++++----
 .../net/consensys/cava/crypto/sodium/Auth.java     |  8 ++++----
 .../java/net/consensys/cava/crypto/sodium/Box.java |  8 ++++----
 .../consensys/cava/crypto/sodium/Concatenate.java  |  8 ++++----
 .../sodium/DefaultDetachedEncryptionResult.java    |  8 ++++----
 .../crypto/sodium/DetachedEncryptionResult.java    |  8 ++++----
 .../consensys/cava/crypto/sodium/DiffieHelman.java |  8 ++++----
 .../consensys/cava/crypto/sodium/GenericHash.java  |  8 ++++----
 .../consensys/cava/crypto/sodium/HMACSHA256.java   |  8 ++++----
 .../consensys/cava/crypto/sodium/HMACSHA512.java   |  8 ++++----
 .../cava/crypto/sodium/HMACSHA512256.java          |  8 ++++----
 .../cava/crypto/sodium/KeyDerivation.java          |  8 ++++----
 .../consensys/cava/crypto/sodium/KeyExchange.java  |  8 ++++----
 .../consensys/cava/crypto/sodium/LibSodium.java    |  8 ++++----
 .../consensys/cava/crypto/sodium/PasswordHash.java |  8 ++++----
 .../consensys/cava/crypto/sodium/SHA256Hash.java   |  8 ++++----
 .../consensys/cava/crypto/sodium/SecretBox.java    |  8 ++++----
 .../cava/crypto/sodium/SecretDecryptionStream.java |  8 ++++----
 .../cava/crypto/sodium/SecretEncryptionStream.java |  8 ++++----
 .../consensys/cava/crypto/sodium/Signature.java    |  8 ++++----
 .../net/consensys/cava/crypto/sodium/Sodium.java   |  8 ++++----
 .../cava/crypto/sodium/SodiumException.java        |  8 ++++----
 .../cava/crypto/sodium/SodiumVersion.java          |  8 ++++----
 .../cava/crypto/sodium/XChaCha20Poly1305.java      |  8 ++++----
 .../java/net/consensys/cava/crypto/HashTest.java   |  8 ++++----
 .../net/consensys/cava/crypto/SECP256K1Test.java   |  8 ++++----
 .../cava/crypto/mikuli/SignatureTest.java          |  8 ++++----
 .../cava/crypto/sodium/AES256GCMTest.java          |  8 ++++----
 .../cava/crypto/sodium/AllocatedTest.java          |  8 ++++----
 .../net/consensys/cava/crypto/sodium/AuthTest.java |  8 ++++----
 .../net/consensys/cava/crypto/sodium/BoxTest.java  |  8 ++++----
 .../cava/crypto/sodium/ConcatenateTest.java        |  8 ++++----
 .../cava/crypto/sodium/DiffieHelmanTest.java       |  8 ++++----
 .../cava/crypto/sodium/GenericHashTest.java        |  8 ++++----
 .../cava/crypto/sodium/HMACSHA256Test.java         |  8 ++++----
 .../cava/crypto/sodium/HMACSHA512256Test.java      |  8 ++++----
 .../cava/crypto/sodium/HMACSHA512Test.java         |  8 ++++----
 .../cava/crypto/sodium/KeyDerivationTest.java      |  8 ++++----
 .../cava/crypto/sodium/PasswordHashTest.java       |  8 ++++----
 .../cava/crypto/sodium/SHA256HashTest.java         |  8 ++++----
 .../cava/crypto/sodium/SecretBoxTest.java          |  8 ++++----
 .../cava/crypto/sodium/SignatureTest.java          |  8 ++++----
 .../consensys/cava/crypto/sodium/SodiumTest.java   |  8 ++++----
 .../cava/crypto/sodium/XChaCha20Poly1305Test.java  |  8 ++++----
 .../consensys/cava/devp2p/AtomicLongProperty.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/DiscoveryService.kt  | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/devp2p/Endpoint.kt   | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/devp2p/EnodeUri.kt   | 20 ++++++++++++--------
 .../main/kotlin/net/consensys/cava/devp2p/Node.kt  | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/devp2p/Packet.kt     | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/devp2p/PacketType.kt | 20 ++++++++++++--------
 .../main/kotlin/net/consensys/cava/devp2p/Peer.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/PeerRepository.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/PeerRoutingTable.kt  | 20 ++++++++++++--------
 .../cava/devp2p/DiscoveryServiceJavaTest.java      |  8 ++++----
 .../consensys/cava/devp2p/DiscoveryServiceTest.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/EndpointTest.kt      | 20 ++++++++++++--------
 .../cava/devp2p/EphemeralPeerRepositoryTest.kt     | 20 ++++++++++++--------
 .../consensys/cava/devp2p/FindNodePacketTest.kt    | 20 ++++++++++++--------
 .../consensys/cava/devp2p/NeighborsPacketTest.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/PingPacketTest.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/devp2p/PongPacketTest.kt    | 20 ++++++++++++--------
 .../cava/eth/reference/BlockRLPTestSuite.java      |  8 ++++----
 .../cava/eth/reference/MerkleTrieTestSuite.java    |  8 ++++----
 .../cava/eth/reference/RLPReferenceTestSuite.java  |  8 ++++----
 .../consensys/cava/eth/reference/SSZTestSuite.java |  8 ++++----
 .../cava/eth/reference/TransactionTestSuite.java   |  8 ++++----
 .../cava/eth/repository/BlockHeaderFields.kt       | 20 ++++++++++++--------
 .../cava/eth/repository/BlockchainIndex.kt         | 20 ++++++++++++--------
 .../cava/eth/repository/BlockchainRepository.kt    | 20 ++++++++++++--------
 .../eth/repository/TransactionReceiptFields.kt     | 20 ++++++++++++--------
 .../cava/eth/repository/BlockchainIndexTest.kt     | 20 ++++++++++++--------
 .../eth/repository/BlockchainRepositoryTest.kt     | 20 ++++++++++++--------
 .../main/java/net/consensys/cava/eth/Address.java  |  8 ++++----
 .../main/java/net/consensys/cava/eth/Block.java    |  8 ++++----
 .../java/net/consensys/cava/eth/BlockBody.java     |  8 ++++----
 .../java/net/consensys/cava/eth/BlockHeader.java   |  8 ++++----
 eth/src/main/java/net/consensys/cava/eth/Hash.java |  8 ++++----
 eth/src/main/java/net/consensys/cava/eth/Log.java  |  8 ++++----
 .../net/consensys/cava/eth/LogsBloomFilter.java    |  8 ++++----
 .../java/net/consensys/cava/eth/Transaction.java   |  8 ++++----
 .../net/consensys/cava/eth/TransactionReceipt.java |  8 ++++----
 .../java/net/consensys/cava/eth/BlockBodyTest.java |  8 ++++----
 .../net/consensys/cava/eth/BlockHeaderTest.java    |  8 ++++----
 .../java/net/consensys/cava/eth/BlockTest.java     |  8 ++++----
 .../test/java/net/consensys/cava/eth/LogTest.java  |  8 ++++----
 .../consensys/cava/eth/LogsBloomFilterTest.java    |  8 ++++----
 .../consensys/cava/eth/TransactionReceiptTest.java |  8 ++++----
 .../net/consensys/cava/eth/TransactionTest.java    |  8 ++++----
 gradle/spotless.license.java                       | 22 +++++++++++++---------
 io/src/main/java/net/consensys/cava/io/Base64.java |  8 ++++----
 .../java/net/consensys/cava/io/IOConsumer.java     |  8 ++++----
 .../net/consensys/cava/io/NullOutputStream.java    |  8 ++++----
 .../main/java/net/consensys/cava/io/Resources.java |  8 ++++----
 .../main/java/net/consensys/cava/io/Streams.java   |  8 ++++----
 .../java/net/consensys/cava/io/file/Files.java     |  8 ++++----
 .../java/net/consensys/cava/io/Base64Test.java     |  8 ++++----
 .../java/net/consensys/cava/io/ResourcesTest.java  |  8 ++++----
 .../java/net/consensys/cava/io/StreamsTest.java    |  8 ++++----
 .../java/net/consensys/cava/io/file/FilesTest.java |  8 ++++----
 .../cava/junit/BouncyCastleExtension.java          |  8 ++++----
 .../java/net/consensys/cava/junit/LuceneIndex.java |  8 ++++----
 .../consensys/cava/junit/LuceneIndexWriter.java    |  8 ++++----
 .../cava/junit/LuceneIndexWriterExtension.java     | 15 ++++++++-------
 .../java/net/consensys/cava/junit/RedisPort.java   |  8 ++++----
 .../consensys/cava/junit/RedisServerExtension.java |  8 ++++----
 .../net/consensys/cava/junit/TempDirectory.java    |  8 ++++----
 .../cava/junit/TempDirectoryExtension.java         |  8 ++++----
 .../net/consensys/cava/junit/VertxExtension.java   |  8 ++++----
 .../net/consensys/cava/junit/VertxInstance.java    |  8 ++++----
 .../cava/junit/LuceneIndexWriterExtensionTest.java |  9 +++++----
 .../cava/junit/RedisServerExtensionTest.java       |  8 ++++----
 .../cava/junit/TempDirectoryExtensionTest.java     |  8 ++++----
 .../cava/kademlia/KademliaRoutingTable.kt          | 20 ++++++++++++--------
 .../cava/kademlia/KademliaRoutingTableTest.kt      | 20 ++++++++++++--------
 .../cava/kademlia/LogarithmicDistanceTest.kt       | 20 ++++++++++++--------
 .../consensys/cava/kademlia/OrderedInsertTest.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/kv/RedisBytesCodec.java     |  8 ++++----
 .../consensys/cava/kv/InfinispanKeyValueStore.kt   | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/kv/KeyValueStore.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/kv/LevelDBKeyValueStore.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/kv/MapDBKeyValueStore.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/kv/MapKeyValueStore.kt      | 20 ++++++++++++--------
 .../net/consensys/cava/kv/RedisKeyValueStore.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/kv/RocksDBKeyValueStore.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/kv/SQLKeyValueStore.kt      | 20 ++++++++++++--------
 .../net/consensys/cava/kv/KeyValueStoreTest.java   |  8 ++++----
 .../consensys/cava/kv/RedisKeyValueStoreTest.java  |  8 ++++----
 .../net/consensys/cava/kv/KeyValueStoreSpec.kt     | 20 ++++++++++++--------
 .../net/consensys/cava/les/BlockBodiesMessage.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/les/BlockHeadersMessage.kt  | 20 ++++++++++++--------
 .../consensys/cava/les/GetBlockBodiesMessage.kt    | 20 ++++++++++++--------
 .../consensys/cava/les/GetBlockHeadersMessage.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/les/GetReceiptsMessage.kt   | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/les/LESPeerState.kt  | 20 ++++++++++++--------
 .../consensys/cava/les/LESSubProtocolHandler.kt    | 20 ++++++++++++--------
 .../net/consensys/cava/les/LESSubprotocol.kt       | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/les/LightClient.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/les/ReceiptsMessage.kt      | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/les/StatusMessage.kt | 20 ++++++++++++--------
 .../cava/les/LESSubProtocolHandlerTest.kt          | 20 ++++++++++++--------
 .../net/consensys/cava/les/LESSubprotocolTest.kt   | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/les/MessagesTest.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/trie/CompactEncoding.java   |  8 ++++----
 .../kotlin/net/consensys/cava/trie/BranchNode.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/trie/DefaultNodeFactory.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/trie/ExtensionNode.kt       | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/GetVisitor.kt   | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/LeafNode.kt     | 20 ++++++++++++--------
 .../net/consensys/cava/trie/MerklePatriciaTrie.kt  | 20 ++++++++++++--------
 .../net/consensys/cava/trie/MerkleStorage.kt       | 20 ++++++++++++--------
 .../consensys/cava/trie/MerkleStorageException.kt  | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/MerkleTrie.kt   | 20 ++++++++++++--------
 .../main/kotlin/net/consensys/cava/trie/Node.kt    | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/NodeFactory.kt  | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/NodeVisitor.kt  | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/NullNode.kt     | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/PutVisitor.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/trie/RemoveVisitor.kt       | 20 ++++++++++++--------
 .../cava/trie/StoredMerklePatriciaTrie.kt          | 20 ++++++++++++--------
 .../kotlin/net/consensys/cava/trie/StoredNode.kt   | 20 ++++++++++++--------
 .../net/consensys/cava/trie/StoredNodeFactory.kt   | 20 ++++++++++++--------
 .../consensys/cava/trie/CompactEncodingTest.java   |  8 ++++----
 .../cava/trie/MerklePatriciaTrieJavaTest.java      |  8 ++++----
 .../trie/MerklePatriciaTriePerformanceTest.java    |  8 ++++----
 .../trie/StoredMerklePatriciaTrieJavaTest.java     |  8 ++++----
 .../cava/trie/MerklePatriciaTrieKotlinTest.kt      | 20 ++++++++++++--------
 .../trie/StoredMerklePatriciaTrieKotlinTest.kt     | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineByteChannel.kt    | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineChannelGroup.kt   | 20 ++++++++++++--------
 .../net/coroutines/CoroutineDatagramChannel.kt     | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineNetworkChannel.kt | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineSelector.kt       | 20 ++++++++++++--------
 .../net/coroutines/CoroutineServerSocketChannel.kt | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineSocketChannel.kt  | 20 ++++++++++++--------
 .../cava/net/coroutines/SelectorTest.java          |  8 ++++----
 .../net/coroutines/CoroutineChannelGroupTest.kt    | 20 ++++++++++++--------
 .../net/coroutines/CoroutineDatagramChannelTest.kt | 20 ++++++++++++--------
 .../cava/net/coroutines/CoroutineSelectorTest.kt   | 20 ++++++++++++--------
 .../net/coroutines/CoroutineSocketChannelTest.kt   | 20 ++++++++++++--------
 .../net/tls/ClientFingerprintTrustManager.java     |  8 ++++----
 .../net/tls/DelegatingTrustManagerFactory.java     |  8 ++++----
 .../net/tls/FileBackedFingerprintRepository.java   |  8 ++++----
 .../cava/net/tls/FingerprintRepository.java        |  8 ++++----
 .../net/tls/ServerFingerprintTrustManager.java     |  8 ++++----
 .../cava/net/tls/SingleTrustManagerFactory.java    |  8 ++++----
 .../main/java/net/consensys/cava/net/tls/TLS.java  |  8 ++++----
 .../cava/net/tls/TLSEnvironmentException.java      |  8 ++++----
 .../cava/net/tls/TrustManagerFactories.java        |  8 ++++----
 .../cava/net/tls/TrustManagerFactoryWrapper.java   |  8 ++++----
 .../consensys/cava/net/tls/VertxTrustOptions.java  |  8 ++++----
 .../cava/net/tls/ClientCaOrRecordTest.java         |  8 ++++----
 .../consensys/cava/net/tls/ClientCaOrTofuTest.java |  8 ++++----
 .../cava/net/tls/ClientCaOrWhitelistTest.java      |  8 ++++----
 .../consensys/cava/net/tls/ClientRecordTest.java   |  8 ++++----
 .../net/consensys/cava/net/tls/ClientTofuTest.java |  8 ++++----
 .../cava/net/tls/ClientWhitelistTest.java          |  8 ++++----
 .../tls/FileBackedFingerprintRepositoryTest.java   |  8 ++++----
 .../cava/net/tls/InsecureTrustOptions.java         |  8 ++++----
 .../consensys/cava/net/tls/SecurityTestUtils.java  |  8 ++++----
 .../cava/net/tls/ServerCaOrRecordTest.java         |  8 ++++----
 .../consensys/cava/net/tls/ServerCaOrTofaTest.java |  8 ++++----
 .../cava/net/tls/ServerCaOrWhitelistTest.java      |  8 ++++----
 .../consensys/cava/net/tls/ServerRecordTest.java   |  8 ++++----
 .../net/consensys/cava/net/tls/ServerTofaTest.java |  8 ++++----
 .../cava/net/tls/ServerWhitelistTest.java          |  8 ++++----
 .../java/net/consensys/cava/net/tls/TLSTest.java   |  8 ++++----
 .../cava/plumtree/EphemeralPeerRepository.java     |  8 ++++----
 .../consensys/cava/plumtree/MessageHashing.java    |  8 ++++----
 .../net/consensys/cava/plumtree/MessageSender.java |  8 ++++----
 .../java/net/consensys/cava/plumtree/Peer.java     |  8 ++++----
 .../consensys/cava/plumtree/PeerRepository.java    |  8 ++++----
 .../java/net/consensys/cava/plumtree/State.java    |  8 ++++----
 .../net/consensys/cava/plumtree/StateActor.java    |  8 ++++----
 .../consensys/cava/plumtree/StateActorFactory.java |  8 ++++----
 .../net/consensys/cava/plumtree/StateTest.java     |  8 ++++----
 .../consensys/cava/rlp/AccumulatingRLPWriter.java  |  8 ++++----
 .../consensys/cava/rlp/ByteBufferRLPWriter.java    |  8 ++++----
 .../net/consensys/cava/rlp/BytesRLPReader.java     |  8 ++++----
 .../net/consensys/cava/rlp/BytesRLPWriter.java     |  8 ++++----
 .../consensys/cava/rlp/DelegatingRLPWriter.java    |  8 ++++----
 .../net/consensys/cava/rlp/EndOfRLPException.java  |  8 ++++----
 .../cava/rlp/InvalidRLPEncodingException.java      |  8 ++++----
 .../cava/rlp/InvalidRLPTypeException.java          |  8 ++++----
 rlp/src/main/java/net/consensys/cava/rlp/RLP.java  |  8 ++++----
 .../java/net/consensys/cava/rlp/RLPException.java  |  8 ++++----
 .../java/net/consensys/cava/rlp/RLPReader.java     |  8 ++++----
 .../java/net/consensys/cava/rlp/RLPWriter.java     |  8 ++++----
 .../consensys/cava/rlp/ByteBufferWriterTest.java   |  8 ++++----
 .../net/consensys/cava/rlp/BytesRLPReaderTest.java |  8 ++++----
 .../net/consensys/cava/rlp/BytesRLPWriterTest.java |  8 ++++----
 .../cava/rlpx/EthereumIESEncryptionEngine.java     |  8 ++++----
 .../net/consensys/cava/rlpx/HandshakeMessage.java  |  8 ++++----
 .../cava/rlpx/InitiatorHandshakeMessage.java       |  8 ++++----
 .../consensys/cava/rlpx/InvalidMACException.java   |  8 ++++----
 .../cava/rlpx/MemoryWireConnectionsRepository.java |  8 ++++----
 .../net/consensys/cava/rlpx/RLPxConnection.java    |  8 ++++----
 .../consensys/cava/rlpx/RLPxConnectionFactory.java |  8 ++++----
 .../java/net/consensys/cava/rlpx/RLPxMessage.java  |  8 ++++----
 .../java/net/consensys/cava/rlpx/RLPxService.java  |  8 ++++----
 .../cava/rlpx/ResponderHandshakeMessage.java       |  8 ++++----
 .../cava/rlpx/WireConnectionRepository.java        |  8 ++++----
 .../cava/rlpx/vertx/VertxRLPxService.java          |  8 ++++----
 .../net/consensys/cava/rlpx/wire/Capability.java   |  8 ++++----
 .../rlpx/wire/DefaultSubProtocolIdentifier.java    |  8 ++++----
 .../cava/rlpx/wire/DefaultWireConnection.java      |  8 ++++----
 .../cava/rlpx/wire/DisconnectMessage.java          |  8 ++++----
 .../consensys/cava/rlpx/wire/DisconnectReason.java |  8 ++++----
 .../net/consensys/cava/rlpx/wire/HelloMessage.java |  8 ++++----
 .../net/consensys/cava/rlpx/wire/PingMessage.java  |  8 ++++----
 .../net/consensys/cava/rlpx/wire/PongMessage.java  |  8 ++++----
 .../net/consensys/cava/rlpx/wire/SubProtocol.java  |  8 ++++----
 .../cava/rlpx/wire/SubProtocolHandler.java         |  8 ++++----
 .../cava/rlpx/wire/SubProtocolIdentifier.java      |  8 ++++----
 .../consensys/cava/rlpx/wire/WireConnection.java   |  8 ++++----
 .../cava/rlpx/wire/WireProtocolMessage.java        |  8 ++++----
 .../cava/rlpx/RLPxConnectionFactoryTest.java       |  8 ++++----
 .../cava/rlpx/vertx/VertxAcceptanceTest.java       |  8 ++++----
 .../cava/rlpx/vertx/VertxRLPxServiceTest.java      |  8 ++++----
 .../cava/rlpx/wire/DefaultWireConnectionTest.java  |  8 ++++----
 .../cava/rlpx/wire/DisconnectMessageTest.java      |  8 ++++----
 .../consensys/cava/rlpx/wire/HelloMessageTest.java |  8 ++++----
 .../net/consensys/cava/rlpx/wire/PingPongTest.java |  8 ++++----
 .../wire/RLPxConnectionMessageExchangeTest.java    |  8 ++++----
 .../cava/scuttlebutt/discovery/LocalIdentity.java  |  8 ++++----
 .../ScuttlebuttLocalDiscoveryService.java          |  8 ++++----
 .../scuttlebutt/discovery/LocalIdentityTest.java   |  8 ++++----
 .../ScuttlebuttLocalDiscoveryServiceTest.java      |  8 ++++----
 .../scuttlebutt/handshake/HandshakeException.java  |  8 ++++----
 .../SecureScuttlebuttHandshakeClient.java          |  8 ++++----
 .../SecureScuttlebuttHandshakeServer.java          |  8 ++++----
 .../handshake/SecureScuttlebuttStream.java         |  8 ++++----
 .../handshake/SecureScuttlebuttStreamClient.java   |  8 ++++----
 .../handshake/SecureScuttlebuttStreamServer.java   |  8 ++++----
 .../scuttlebutt/handshake/StreamException.java     |  8 ++++----
 .../scuttlebutt/handshake/vertx/ClientHandler.java |  8 ++++----
 .../handshake/vertx/ClientHandlerFactory.java      |  8 ++++----
 .../vertx/SecureScuttlebuttVertxClient.java        |  8 ++++----
 .../vertx/SecureScuttlebuttVertxServer.java        |  8 ++++----
 .../scuttlebutt/handshake/vertx/ServerHandler.java |  8 ++++----
 .../handshake/vertx/ServerHandlerFactory.java      |  8 ++++----
 .../SecureScuttlebuttHandshakeClientTest.java      |  8 ++++----
 .../handshake/SecureScuttlebuttStreamTest.java     |  8 ++++----
 .../handshake/vertx/VertxIntegrationTest.java      |  8 ++++----
 .../consensys/cava/scuttlebutt/rpc/RPCCodec.java   |  8 ++++----
 .../consensys/cava/scuttlebutt/rpc/RPCFlag.java    |  8 ++++----
 .../consensys/cava/scuttlebutt/rpc/RPCMessage.java |  8 ++++----
 .../scuttlebutt/rpc/PatchworkIntegrationTest.java  |  8 ++++----
 .../cava/scuttlebutt/rpc/RPCEncodingTest.java      |  8 ++++----
 .../cava/scuttlebutt/rpc/RPCFlagTest.java          |  8 ++++----
 .../cava/scuttlebutt/Ed25519KeyPairIdentity.java   |  8 ++++----
 .../cava/scuttlebutt/Ed25519PublicKeyIdentity.java |  8 ++++----
 .../net/consensys/cava/scuttlebutt/Identity.java   |  8 ++++----
 .../net/consensys/cava/scuttlebutt/Invite.java     |  8 ++++----
 .../cava/scuttlebutt/SECP256K1KeyPairIdentity.java |  8 ++++----
 .../scuttlebutt/SECP256K1PublicKeyIdentity.java    |  8 ++++----
 .../consensys/cava/scuttlebutt/IdentityTest.java   |  8 ++++----
 .../net/consensys/cava/scuttlebutt/InviteTest.java |  8 ++++----
 .../consensys/cava/ssz/ByteBufferSSZWriter.java    |  8 ++++----
 .../net/consensys/cava/ssz/BytesSSZReader.java     |  8 ++++----
 .../net/consensys/cava/ssz/BytesSSZWriter.java     |  8 ++++----
 .../net/consensys/cava/ssz/EndOfSSZException.java  |  8 ++++----
 .../cava/ssz/InvalidSSZTypeException.java          |  8 ++++----
 ssz/src/main/java/net/consensys/cava/ssz/SSZ.java  |  8 ++++----
 .../java/net/consensys/cava/ssz/SSZException.java  |  8 ++++----
 .../java/net/consensys/cava/ssz/SSZReader.java     |  8 ++++----
 .../java/net/consensys/cava/ssz/SSZWriter.java     |  8 ++++----
 .../cava/ssz/experimental/BytesSSZReader.kt        | 20 ++++++++++++--------
 .../cava/ssz/experimental/BytesSSZWriter.kt        | 20 ++++++++++++--------
 .../net/consensys/cava/ssz/experimental/SSZ.kt     | 20 ++++++++++++--------
 .../consensys/cava/ssz/experimental/SSZReader.kt   | 20 ++++++++++++--------
 .../consensys/cava/ssz/experimental/SSZWriter.kt   | 20 ++++++++++++--------
 .../consensys/cava/ssz/ByteBufferWriterTest.java   |  8 ++++----
 .../net/consensys/cava/ssz/BytesSSZReaderTest.java |  8 ++++----
 .../net/consensys/cava/ssz/BytesSSZWriterTest.java |  8 ++++----
 .../net/consensys/cava/ssz/HashTreeRootTest.java   |  8 ++++----
 .../net/consensys/cava/ssz/experimental/SSZTest.kt | 20 ++++++++++++--------
 .../cava/toml/AccumulatingErrorListener.java       |  8 ++++----
 .../java/net/consensys/cava/toml/ArrayVisitor.java |  8 ++++----
 .../net/consensys/cava/toml/ErrorReporter.java     |  8 ++++----
 .../consensys/cava/toml/InlineTableVisitor.java    |  8 ++++----
 .../net/consensys/cava/toml/JsonSerializer.java    |  8 ++++----
 .../java/net/consensys/cava/toml/KeyVisitor.java   |  8 ++++----
 .../java/net/consensys/cava/toml/LineVisitor.java  |  8 ++++----
 .../net/consensys/cava/toml/LocalDateVisitor.java  |  8 ++++----
 .../net/consensys/cava/toml/LocalTimeVisitor.java  |  8 ++++----
 .../net/consensys/cava/toml/MutableTomlArray.java  |  8 ++++----
 .../net/consensys/cava/toml/MutableTomlTable.java  |  8 ++++----
 .../main/java/net/consensys/cava/toml/Parser.java  |  8 ++++----
 .../consensys/cava/toml/QuotedStringVisitor.java   |  8 ++++----
 .../java/net/consensys/cava/toml/TokenName.java    |  8 ++++----
 .../main/java/net/consensys/cava/toml/Toml.java    |  8 ++++----
 .../java/net/consensys/cava/toml/TomlArray.java    |  8 ++++----
 .../cava/toml/TomlInvalidTypeException.java        |  8 ++++----
 .../net/consensys/cava/toml/TomlParseError.java    |  8 ++++----
 .../net/consensys/cava/toml/TomlParseResult.java   |  8 ++++----
 .../java/net/consensys/cava/toml/TomlPosition.java |  8 ++++----
 .../java/net/consensys/cava/toml/TomlTable.java    |  8 ++++----
 .../java/net/consensys/cava/toml/TomlType.java     |  8 ++++----
 .../java/net/consensys/cava/toml/TomlVersion.java  |  8 ++++----
 .../java/net/consensys/cava/toml/ValueVisitor.java |  8 ++++----
 .../net/consensys/cava/toml/ZoneOffsetVisitor.java |  8 ++++----
 .../consensys/cava/toml/MutableTomlArrayTest.java  |  8 ++++----
 .../consensys/cava/toml/MutableTomlTableTest.java  |  8 ++++----
 .../net/consensys/cava/toml/TokenNameTest.java     |  8 ++++----
 .../java/net/consensys/cava/toml/TomlTest.java     |  8 ++++----
 .../cava/units/bigints/BaseUInt256Value.java       |  8 ++++----
 .../cava/units/bigints/BaseUInt384Value.java       |  8 ++++----
 .../cava/units/bigints/BaseUInt64Value.java        |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt256.java  |  8 ++++----
 .../cava/units/bigints/UInt256Domain.java          |  8 ++++----
 .../consensys/cava/units/bigints/UInt256Value.java |  8 ++++----
 .../cava/units/bigints/UInt256ValueDomain.java     |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt256s.java |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt384.java  |  8 ++++----
 .../cava/units/bigints/UInt384Domain.java          |  8 ++++----
 .../consensys/cava/units/bigints/UInt384Value.java |  8 ++++----
 .../cava/units/bigints/UInt384ValueDomain.java     |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt384s.java |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt64.java   |  8 ++++----
 .../consensys/cava/units/bigints/UInt64Domain.java |  8 ++++----
 .../consensys/cava/units/bigints/UInt64Value.java  |  8 ++++----
 .../cava/units/bigints/UInt64ValueDomain.java      |  8 ++++----
 .../net/consensys/cava/units/bigints/UInt64s.java  |  8 ++++----
 .../net/consensys/cava/units/ethereum/Gas.java     |  8 ++++----
 .../net/consensys/cava/units/ethereum/Wei.java     |  8 ++++----
 .../cava/units/bigints/BaseUInt256ValueTest.java   |  8 ++++----
 .../cava/units/bigints/BaseUInt384ValueTest.java   |  8 ++++----
 .../cava/units/bigints/BaseUInt64ValueTest.java    |  8 ++++----
 .../consensys/cava/units/bigints/UInt256Test.java  |  8 ++++----
 .../consensys/cava/units/bigints/UInt384Test.java  |  8 ++++----
 .../consensys/cava/units/bigints/UInt64Test.java   |  8 ++++----
 .../net/consensys/cava/units/ethereum/GasTest.java |  8 ++++----
 .../net/consensys/cava/units/ethereum/WeiTest.java |  8 ++++----
 460 files changed, 2608 insertions(+), 2234 deletions(-)

diff --git a/bytes/src/main/java/net/consensys/cava/bytes/AbstractBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/AbstractBytes.java
index 25c186e..7c19c7a 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/AbstractBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/AbstractBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes.java
index 1fa0439..0255817 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes32.java
index babc70c..e609f41 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes48.java
index 6f64a17..4ec8dbe 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ArrayWrappingBytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/BufferWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/BufferWrappingBytes.java
index 2563cc3..6020c82 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/BufferWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/BufferWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ByteBufWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/ByteBufWrappingBytes.java
index f2be78f..0d4ec47 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ByteBufWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ByteBufWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ByteBufferWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/ByteBufferWrappingBytes.java
index 26607b4..c1b02b0 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ByteBufferWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ByteBufferWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/Bytes.java b/bytes/src/main/java/net/consensys/cava/bytes/Bytes.java
index 91c1df9..23561bc 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/Bytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/Bytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/Bytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/Bytes32.java
index da6a6ef..571ac90 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/Bytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/Bytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/Bytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/Bytes48.java
index ae00c9b..518e5cf 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/Bytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/Bytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/BytesValues.java b/bytes/src/main/java/net/consensys/cava/bytes/BytesValues.java
index 13b78f9..6a14bd7 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/BytesValues.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/BytesValues.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/ConcatenatedBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/ConcatenatedBytes.java
index b678ce9..39cd362 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/ConcatenatedBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/ConcatenatedBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes32.java
index 061fddc..c29a60a 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes48.java
index 62dcaeb..9f3198d 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingBytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes32.java
index 278414f..dbfec11 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes48.java
index 7e8dfe7..0086494 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/DelegatingMutableBytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes.java
index 8474e0d..a932521 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes32.java
index d5ead47..0cf5096 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes48.java
index a716e06..25bbaeb 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableArrayWrappingBytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableBufferWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableBufferWrappingBytes.java
index 5fbb600..7c5cac8 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableBufferWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableBufferWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufWrappingBytes.java
index e2f6e4d..b190ef4 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufferWrappingBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufferWrappingBytes.java
index 2d6e521..0067529 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufferWrappingBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableByteBufferWrappingBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes.java
index e9717cf..e2363c6 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes32.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes32.java
index 4b5f891..19b0058 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes32.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes32.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes48.java b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes48.java
index 801e94c..fc90de4 100644
--- a/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes48.java
+++ b/bytes/src/main/java/net/consensys/cava/bytes/MutableBytes48.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/BufferBytesTest.java b/bytes/src/test/java/net/consensys/cava/bytes/BufferBytesTest.java
index f7b2a20..945f017 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/BufferBytesTest.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/BufferBytesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/ByteBufBytesTest.java b/bytes/src/test/java/net/consensys/cava/bytes/ByteBufBytesTest.java
index 1057610..744590a 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/ByteBufBytesTest.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/ByteBufBytesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/ByteBufferBytesTest.java b/bytes/src/test/java/net/consensys/cava/bytes/ByteBufferBytesTest.java
index 83fce73..db43f22 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/ByteBufferBytesTest.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/ByteBufferBytesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/Bytes32Test.java b/bytes/src/test/java/net/consensys/cava/bytes/Bytes32Test.java
index 28f2ab6..c42aa9c 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/Bytes32Test.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/Bytes32Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/Bytes48Test.java b/bytes/src/test/java/net/consensys/cava/bytes/Bytes48Test.java
index bde9bdb..e3114a8 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/Bytes48Test.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/Bytes48Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/BytesTest.java b/bytes/src/test/java/net/consensys/cava/bytes/BytesTest.java
index 7236b88..3ccd344 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/BytesTest.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/BytesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/CommonBytesTests.java b/bytes/src/test/java/net/consensys/cava/bytes/CommonBytesTests.java
index 993135b..b387ba5 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/CommonBytesTests.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/CommonBytesTests.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/bytes/src/test/java/net/consensys/cava/bytes/ConcatenatedBytesTest.java b/bytes/src/test/java/net/consensys/cava/bytes/ConcatenatedBytesTest.java
index 38d26fd..b4489b1 100644
--- a/bytes/src/test/java/net/consensys/cava/bytes/ConcatenatedBytesTest.java
+++ b/bytes/src/test/java/net/consensys/cava/bytes/ConcatenatedBytesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncCompletion.kt b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncCompletion.kt
index 2033576..4969918 100644
--- a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncCompletion.kt
+++ b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncCompletion.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncResult.kt b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncResult.kt
index 9508d69..f3b324c 100644
--- a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncResult.kt
+++ b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/AsyncResult.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatch.kt b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatch.kt
index 1723644..0dfd10d 100644
--- a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatch.kt
+++ b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatch.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/Retryable.kt b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/Retryable.kt
index 49d92a2..941bfe6 100644
--- a/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/Retryable.kt
+++ b/concurrent-coroutines/src/main/kotlin/net/consensys/cava/concurrent/coroutines/Retryable.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatchTest.kt b/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatchTest.kt
index 07899fb..61ab68c 100644
--- a/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatchTest.kt
+++ b/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/CoroutineLatchTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/RetryableTest.kt b/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/RetryableTest.kt
index c6f71f8..d231fac 100644
--- a/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/RetryableTest.kt
+++ b/concurrent-coroutines/src/test/kotlin/net/consensys/cava/concurrent/coroutines/RetryableTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.concurrent.coroutines
 
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncCompletion.java b/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncCompletion.java
index 77b2471..c495ce6 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncCompletion.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncCompletion.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncResult.java b/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncResult.java
index d3214e3..afef9f4 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncResult.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/AsyncResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/AtomicSlotMap.java b/concurrent/src/main/java/net/consensys/cava/concurrent/AtomicSlotMap.java
index 6b6eba2..65682bf 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/AtomicSlotMap.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/AtomicSlotMap.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncCompletion.java b/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncCompletion.java
index 49fe75e..5b0cb90 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncCompletion.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncCompletion.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncResult.java b/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncResult.java
index 0665519..f1a7b06 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncResult.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/CompletableAsyncResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletion.java b/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletion.java
index e4ae055..8d17b8e 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletion.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletion.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResult.java b/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResult.java
index 37bc55c..1faf6bc 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResult.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringMap.java b/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringMap.java
index 2e4cbbd..950c8d7 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringMap.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringMap.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringSet.java b/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringSet.java
index 5163714..0c5e02e 100644
--- a/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringSet.java
+++ b/concurrent/src/main/java/net/consensys/cava/concurrent/ExpiringSet.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/test/java/net/consensys/cava/concurrent/AtomicSlotMapTest.java b/concurrent/src/test/java/net/consensys/cava/concurrent/AtomicSlotMapTest.java
index ee08bb2..4019b10 100644
--- a/concurrent/src/test/java/net/consensys/cava/concurrent/AtomicSlotMapTest.java
+++ b/concurrent/src/test/java/net/consensys/cava/concurrent/AtomicSlotMapTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletionTest.java b/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletionTest.java
index 17fbb89..ff67695 100644
--- a/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletionTest.java
+++ b/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncCompletionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResultTest.java b/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResultTest.java
index 002c6bf..9680b8f 100644
--- a/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResultTest.java
+++ b/concurrent/src/test/java/net/consensys/cava/concurrent/DefaultCompletableAsyncResultTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringMapTest.java b/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringMapTest.java
index 2a58b53..83881b9 100644
--- a/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringMapTest.java
+++ b/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringMapTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringSetTest.java b/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringSetTest.java
index 99837ae..e190859 100644
--- a/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringSetTest.java
+++ b/concurrent/src/test/java/net/consensys/cava/concurrent/ExpiringSetTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/Configuration.java b/config/src/main/java/net/consensys/cava/config/Configuration.java
index 83aed67..46a64c9 100644
--- a/config/src/main/java/net/consensys/cava/config/Configuration.java
+++ b/config/src/main/java/net/consensys/cava/config/Configuration.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/ConfigurationError.java b/config/src/main/java/net/consensys/cava/config/ConfigurationError.java
index 646b8b1..1d81a9d 100644
--- a/config/src/main/java/net/consensys/cava/config/ConfigurationError.java
+++ b/config/src/main/java/net/consensys/cava/config/ConfigurationError.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/ConfigurationErrors.java b/config/src/main/java/net/consensys/cava/config/ConfigurationErrors.java
index 5fce1c8..75a0f28 100644
--- a/config/src/main/java/net/consensys/cava/config/ConfigurationErrors.java
+++ b/config/src/main/java/net/consensys/cava/config/ConfigurationErrors.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/ConfigurationValidator.java b/config/src/main/java/net/consensys/cava/config/ConfigurationValidator.java
index 4b2a70e..9de3ac3 100644
--- a/config/src/main/java/net/consensys/cava/config/ConfigurationValidator.java
+++ b/config/src/main/java/net/consensys/cava/config/ConfigurationValidator.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/DocumentPosition.java b/config/src/main/java/net/consensys/cava/config/DocumentPosition.java
index e7ccfbf..aca2edf 100644
--- a/config/src/main/java/net/consensys/cava/config/DocumentPosition.java
+++ b/config/src/main/java/net/consensys/cava/config/DocumentPosition.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/EmptyConfiguration.java b/config/src/main/java/net/consensys/cava/config/EmptyConfiguration.java
index 020152b..6f1bb6b 100644
--- a/config/src/main/java/net/consensys/cava/config/EmptyConfiguration.java
+++ b/config/src/main/java/net/consensys/cava/config/EmptyConfiguration.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/InvalidConfigurationPropertyTypeException.java b/config/src/main/java/net/consensys/cava/config/InvalidConfigurationPropertyTypeException.java
index d81e5ec..5e2fe46 100644
--- a/config/src/main/java/net/consensys/cava/config/InvalidConfigurationPropertyTypeException.java
+++ b/config/src/main/java/net/consensys/cava/config/InvalidConfigurationPropertyTypeException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/NoConfigurationPropertyException.java b/config/src/main/java/net/consensys/cava/config/NoConfigurationPropertyException.java
index 6ed89ff..69558b6 100644
--- a/config/src/main/java/net/consensys/cava/config/NoConfigurationPropertyException.java
+++ b/config/src/main/java/net/consensys/cava/config/NoConfigurationPropertyException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/PropertyValidator.java b/config/src/main/java/net/consensys/cava/config/PropertyValidator.java
index fa03b17..c09e1d4 100644
--- a/config/src/main/java/net/consensys/cava/config/PropertyValidator.java
+++ b/config/src/main/java/net/consensys/cava/config/PropertyValidator.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/PropertyValidators.java b/config/src/main/java/net/consensys/cava/config/PropertyValidators.java
index e576e6b..4bb1d1f 100644
--- a/config/src/main/java/net/consensys/cava/config/PropertyValidators.java
+++ b/config/src/main/java/net/consensys/cava/config/PropertyValidators.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/Schema.java b/config/src/main/java/net/consensys/cava/config/Schema.java
index 309df3a..a63e165 100644
--- a/config/src/main/java/net/consensys/cava/config/Schema.java
+++ b/config/src/main/java/net/consensys/cava/config/Schema.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/SchemaBuilder.java b/config/src/main/java/net/consensys/cava/config/SchemaBuilder.java
index 5fe2f69..0e0d9e6 100644
--- a/config/src/main/java/net/consensys/cava/config/SchemaBuilder.java
+++ b/config/src/main/java/net/consensys/cava/config/SchemaBuilder.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/TomlBackedConfiguration.java b/config/src/main/java/net/consensys/cava/config/TomlBackedConfiguration.java
index 5db73b4..622f20d 100644
--- a/config/src/main/java/net/consensys/cava/config/TomlBackedConfiguration.java
+++ b/config/src/main/java/net/consensys/cava/config/TomlBackedConfiguration.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/main/java/net/consensys/cava/config/TomlSerializer.java b/config/src/main/java/net/consensys/cava/config/TomlSerializer.java
index 68f17ec..72c9e5c 100644
--- a/config/src/main/java/net/consensys/cava/config/TomlSerializer.java
+++ b/config/src/main/java/net/consensys/cava/config/TomlSerializer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/test/java/net/consensys/cava/config/PropertyValidatorTest.java b/config/src/test/java/net/consensys/cava/config/PropertyValidatorTest.java
index b32e06a..17e44cf 100644
--- a/config/src/test/java/net/consensys/cava/config/PropertyValidatorTest.java
+++ b/config/src/test/java/net/consensys/cava/config/PropertyValidatorTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/test/java/net/consensys/cava/config/SchemaBuilderTest.java b/config/src/test/java/net/consensys/cava/config/SchemaBuilderTest.java
index 438cfab..e5ad482 100644
--- a/config/src/test/java/net/consensys/cava/config/SchemaBuilderTest.java
+++ b/config/src/test/java/net/consensys/cava/config/SchemaBuilderTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/config/src/test/java/net/consensys/cava/config/TomlBackedConfigurationTest.java b/config/src/test/java/net/consensys/cava/config/TomlBackedConfigurationTest.java
index 3b46833..a5acb3f 100644
--- a/config/src/test/java/net/consensys/cava/config/TomlBackedConfigurationTest.java
+++ b/config/src/test/java/net/consensys/cava/config/TomlBackedConfigurationTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/Hash.java b/crypto/src/main/java/net/consensys/cava/crypto/Hash.java
index e660343..27970f9 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/Hash.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/Hash.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/InvalidSEC256K1SecretKeyStoreException.java b/crypto/src/main/java/net/consensys/cava/crypto/InvalidSEC256K1SecretKeyStoreException.java
index 641b297..5fe6c31 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/InvalidSEC256K1SecretKeyStoreException.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/InvalidSEC256K1SecretKeyStoreException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/SECP256K1.java b/crypto/src/main/java/net/consensys/cava/crypto/SECP256K1.java
index 3d0b0ee..42a2758 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/SECP256K1.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/SECP256K1.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/AtePairing.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/AtePairing.java
index f5e84b0..ab5d4f4 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/AtePairing.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/AtePairing.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/BLS12381.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/BLS12381.java
index a867f60..e1841b7 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/BLS12381.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/BLS12381.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,11 +12,10 @@
  */
 package org.apache.tuweni.crypto.mikuli;
 
-import org.apache.tuweni.bytes.Bytes;
-
 import org.apache.milagro.amcl.BLS381.ECP;
 import org.apache.milagro.amcl.BLS381.ECP2;
 import org.apache.milagro.amcl.BLS381.MPIN;
+import org.apache.tuweni.bytes.Bytes;
 
 /*
  * Adapted from the ConsenSys/mikuli (Apache 2 License) implementation:
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G1Point.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G1Point.java
index e472f83..550bc29 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G1Point.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G1Point.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,13 +12,12 @@
  */
 package org.apache.tuweni.crypto.mikuli;
 
+import org.apache.milagro.amcl.BLS381.BIG;
+import org.apache.milagro.amcl.BLS381.ECP;
 import org.apache.tuweni.bytes.Bytes;
 
 import java.util.Objects;
 
-import org.apache.milagro.amcl.BLS381.BIG;
-import org.apache.milagro.amcl.BLS381.ECP;
-
 /**
  * G1 is a subgroup of an elliptic curve whose points are elements of the finite field Fp - simple numbers mod some
  * prime p. The curve is defined by: y^2 = x^3 + 4
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G2Point.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G2Point.java
index fafb509..c8c7f8f 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G2Point.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/G2Point.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,13 +12,12 @@
  */
 package org.apache.tuweni.crypto.mikuli;
 
+import org.apache.milagro.amcl.BLS381.BIG;
+import org.apache.milagro.amcl.BLS381.ECP2;
 import org.apache.tuweni.bytes.Bytes;
 
 import java.util.Objects;
 
-import org.apache.milagro.amcl.BLS381.BIG;
-import org.apache.milagro.amcl.BLS381.ECP2;
-
 /**
  * G2 is the subgroup of elliptic curve similar to G1 and the points are identical except for where they are elements of
  * the extension field Fq12.
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/GTPoint.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/GTPoint.java
index e19bf37..a7ef341 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/GTPoint.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/GTPoint.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,10 +12,10 @@
  */
 package org.apache.tuweni.crypto.mikuli;
 
-import java.util.Objects;
-
 import org.apache.milagro.amcl.BLS381.FP12;
 
+import java.util.Objects;
+
 /**
  * GT is the object that holds the result of the pairing operation. Points in GT are elements of Fq12.
  */
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Group.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Group.java
index 30a67f2..b98fd20 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Group.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Group.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/KeyPair.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/KeyPair.java
index 6ea890b..a87359a 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/KeyPair.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/KeyPair.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/PublicKey.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/PublicKey.java
index 5ba81ff..7362b88 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/PublicKey.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/PublicKey.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Scalar.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Scalar.java
index ae2de0a..9a437b9 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Scalar.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Scalar.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,10 +12,10 @@
  */
 package org.apache.tuweni.crypto.mikuli;
 
-import java.util.Objects;
-
 import org.apache.milagro.amcl.BLS381.BIG;
 
+import java.util.Objects;
+
 /**
  * This class represents an ordinary scalar value.
  */
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SecretKey.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SecretKey.java
index 2bbb86c..1ef2b94 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SecretKey.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SecretKey.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -14,12 +14,11 @@ package org.apache.tuweni.crypto.mikuli;
 
 import static org.apache.milagro.amcl.BLS381.BIG.MODBYTES;
 
+import org.apache.milagro.amcl.BLS381.BIG;
 import org.apache.tuweni.bytes.Bytes;
 
 import java.util.Objects;
 
-import org.apache.milagro.amcl.BLS381.BIG;
-
 /**
  * This class represents a BLS12-381 private key.
  */
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Signature.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Signature.java
index 0a37427..ed7e2ec 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Signature.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/Signature.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SignatureAndPublicKey.java b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SignatureAndPublicKey.java
index 14d66a9..8146b80 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SignatureAndPublicKey.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/mikuli/SignatureAndPublicKey.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/AES256GCM.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/AES256GCM.java
index 1ce47c2..c5b58fd 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/AES256GCM.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/AES256GCM.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Allocated.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Allocated.java
index ed28dd6..7d5c37e 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Allocated.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Allocated.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Auth.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Auth.java
index eb21f25..d163376 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Auth.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Auth.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Box.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Box.java
index bbabb8e..9df2dc8 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Box.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Box.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Concatenate.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Concatenate.java
index e1cba0c..2ec36b2 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Concatenate.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Concatenate.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DefaultDetachedEncryptionResult.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DefaultDetachedEncryptionResult.java
index 4ae6ff0..535a997 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DefaultDetachedEncryptionResult.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DefaultDetachedEncryptionResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DetachedEncryptionResult.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DetachedEncryptionResult.java
index d06512a..4a57ee6 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DetachedEncryptionResult.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DetachedEncryptionResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DiffieHelman.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DiffieHelman.java
index 16d8e35..3ee9ddb 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/DiffieHelman.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/DiffieHelman.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/GenericHash.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/GenericHash.java
index 4930efb..a6005b2 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/GenericHash.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/GenericHash.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA256.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA256.java
index 531618a..bc4aec4 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA256.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA256.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512.java
index 9c7c3eb..7d655ec 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512256.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512256.java
index 25437ef..f4ca923 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512256.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/HMACSHA512256.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyDerivation.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyDerivation.java
index 117c931..71439fd 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyDerivation.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyDerivation.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyExchange.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyExchange.java
index 1890d74..e604ec2 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyExchange.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/KeyExchange.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/LibSodium.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/LibSodium.java
index 54471a1..7496fb3 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/LibSodium.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/LibSodium.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/PasswordHash.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/PasswordHash.java
index 9c92401..e912296 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/PasswordHash.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/PasswordHash.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SHA256Hash.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SHA256Hash.java
index 952c1ca..39f16f6 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SHA256Hash.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SHA256Hash.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretBox.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretBox.java
index 4583d79..6f595e9 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretBox.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretBox.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretDecryptionStream.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretDecryptionStream.java
index 2b14fcf..95b12a7 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretDecryptionStream.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretDecryptionStream.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretEncryptionStream.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretEncryptionStream.java
index 1da6361..c294e0c 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretEncryptionStream.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SecretEncryptionStream.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Signature.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Signature.java
index b443b14..ac0a0bd 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Signature.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Signature.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Sodium.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Sodium.java
index 163b7e3..e76d587 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/Sodium.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/Sodium.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumException.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumException.java
index 87800dd..f34d422 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumException.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumVersion.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumVersion.java
index 982c437..8b54098 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumVersion.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/SodiumVersion.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/main/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305.java b/crypto/src/main/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305.java
index 4af499b..e63e5fe 100644
--- a/crypto/src/main/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305.java
+++ b/crypto/src/main/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/HashTest.java b/crypto/src/test/java/net/consensys/cava/crypto/HashTest.java
index 7bcd54a..87afe6e 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/HashTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/HashTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/SECP256K1Test.java b/crypto/src/test/java/net/consensys/cava/crypto/SECP256K1Test.java
index 3cc61af..f8e3729 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/SECP256K1Test.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/SECP256K1Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/mikuli/SignatureTest.java b/crypto/src/test/java/net/consensys/cava/crypto/mikuli/SignatureTest.java
index 266731c..82b4265 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/mikuli/SignatureTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/mikuli/SignatureTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AES256GCMTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AES256GCMTest.java
index b84da6e..f63f006 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AES256GCMTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AES256GCMTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AllocatedTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AllocatedTest.java
index b47c550..2a0e01d 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AllocatedTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AllocatedTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AuthTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AuthTest.java
index 2053b73..35a8da3 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/AuthTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/AuthTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/BoxTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/BoxTest.java
index d6e0217..950e9ae 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/BoxTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/BoxTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/ConcatenateTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/ConcatenateTest.java
index 84dec45..5feb6c3 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/ConcatenateTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/ConcatenateTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/DiffieHelmanTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/DiffieHelmanTest.java
index 591ae07..cc053c5 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/DiffieHelmanTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/DiffieHelmanTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/GenericHashTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/GenericHashTest.java
index 2e6947a..9e5193e 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/GenericHashTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/GenericHashTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA256Test.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA256Test.java
index 597bd70..eb54da1 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA256Test.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA256Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512256Test.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512256Test.java
index 9107aa2..07c3791 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512256Test.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512256Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512Test.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512Test.java
index b6a1f6c..243cb25 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512Test.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/HMACSHA512Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/KeyDerivationTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/KeyDerivationTest.java
index edf0fc5..6fcddb1 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/KeyDerivationTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/KeyDerivationTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/PasswordHashTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/PasswordHashTest.java
index 899c6df..7895533 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/PasswordHashTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/PasswordHashTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SHA256HashTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SHA256HashTest.java
index 46e542f..4006cb6 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SHA256HashTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SHA256HashTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SecretBoxTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SecretBoxTest.java
index 79d6a56..c1de822 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SecretBoxTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SecretBoxTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SignatureTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SignatureTest.java
index bb79c0a..2245316 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SignatureTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SignatureTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SodiumTest.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SodiumTest.java
index 42761cc..25715b5 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/SodiumTest.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/SodiumTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/crypto/src/test/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305Test.java b/crypto/src/test/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305Test.java
index 672c5e1..4ffadeb 100644
--- a/crypto/src/test/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305Test.java
+++ b/crypto/src/test/java/net/consensys/cava/crypto/sodium/XChaCha20Poly1305Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/AtomicLongProperty.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/AtomicLongProperty.kt
index aeac65f..8f42bed 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/AtomicLongProperty.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/AtomicLongProperty.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/DiscoveryService.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/DiscoveryService.kt
index 446b689..793eb91 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/DiscoveryService.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/DiscoveryService.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Endpoint.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Endpoint.kt
index 82d312b..a5effb5 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Endpoint.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Endpoint.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/EnodeUri.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/EnodeUri.kt
index f57b129..225a534 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/EnodeUri.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/EnodeUri.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Node.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Node.kt
index a316be2..f5e38d1 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Node.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Node.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Packet.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Packet.kt
index 89e354a..a46bad1 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Packet.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Packet.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PacketType.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PacketType.kt
index 6a569dd..55b91af 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PacketType.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PacketType.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Peer.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Peer.kt
index 4b81fa6..d281558 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Peer.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/Peer.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRepository.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRepository.kt
index 464a3d3..1271efc 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRepository.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRepository.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRoutingTable.kt b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRoutingTable.kt
index 4c5a771..a6dc884 100644
--- a/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRoutingTable.kt
+++ b/devp2p/src/main/kotlin/net/consensys/cava/devp2p/PeerRoutingTable.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/java/net/consensys/cava/devp2p/DiscoveryServiceJavaTest.java b/devp2p/src/test/java/net/consensys/cava/devp2p/DiscoveryServiceJavaTest.java
index 512a6d8..bcaae43 100644
--- a/devp2p/src/test/java/net/consensys/cava/devp2p/DiscoveryServiceJavaTest.java
+++ b/devp2p/src/test/java/net/consensys/cava/devp2p/DiscoveryServiceJavaTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/DiscoveryServiceTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/DiscoveryServiceTest.kt
index a32e2cc..cd0c7dc 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/DiscoveryServiceTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/DiscoveryServiceTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EndpointTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EndpointTest.kt
index b142a48..174c608 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EndpointTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EndpointTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EphemeralPeerRepositoryTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EphemeralPeerRepositoryTest.kt
index 6da2e40..9340006 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EphemeralPeerRepositoryTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/EphemeralPeerRepositoryTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/FindNodePacketTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/FindNodePacketTest.kt
index 87d3d2f..bd538e3 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/FindNodePacketTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/FindNodePacketTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/NeighborsPacketTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/NeighborsPacketTest.kt
index bcb222c..7d9e567 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/NeighborsPacketTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/NeighborsPacketTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PingPacketTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PingPacketTest.kt
index 32705b4..5334cca 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PingPacketTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PingPacketTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PongPacketTest.kt b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PongPacketTest.kt
index f5ac011..82b0f73 100644
--- a/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PongPacketTest.kt
+++ b/devp2p/src/test/kotlin/net/consensys/cava/devp2p/PongPacketTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.devp2p
 
diff --git a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/BlockRLPTestSuite.java b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/BlockRLPTestSuite.java
index 036bec8..86798f8 100644
--- a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/BlockRLPTestSuite.java
+++ b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/BlockRLPTestSuite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/MerkleTrieTestSuite.java b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/MerkleTrieTestSuite.java
index 1d0739c..4988b83 100644
--- a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/MerkleTrieTestSuite.java
+++ b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/MerkleTrieTestSuite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/RLPReferenceTestSuite.java b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/RLPReferenceTestSuite.java
index 69aee9d..0843529 100644
--- a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/RLPReferenceTestSuite.java
+++ b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/RLPReferenceTestSuite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/SSZTestSuite.java b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/SSZTestSuite.java
index 11ae68f..3925f28 100644
--- a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/SSZTestSuite.java
+++ b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/SSZTestSuite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/TransactionTestSuite.java b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/TransactionTestSuite.java
index e9abadc..6f68edc 100644
--- a/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/TransactionTestSuite.java
+++ b/eth-reference-tests/src/test/java/net/consensys/cava/eth/reference/TransactionTestSuite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockHeaderFields.kt b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockHeaderFields.kt
index afe6279..a1c4ca5 100644
--- a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockHeaderFields.kt
+++ b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockHeaderFields.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainIndex.kt b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainIndex.kt
index 7ab7f7e..93067d6 100644
--- a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainIndex.kt
+++ b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainIndex.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainRepository.kt b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainRepository.kt
index a899b62..1012256 100644
--- a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainRepository.kt
+++ b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/BlockchainRepository.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/TransactionReceiptFields.kt b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/TransactionReceiptFields.kt
index b574096..513c688 100644
--- a/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/TransactionReceiptFields.kt
+++ b/eth-repository/src/main/kotlin/net/consensys/cava/eth/repository/TransactionReceiptFields.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainIndexTest.kt b/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainIndexTest.kt
index fa9b3d3..e2a1dc3 100644
--- a/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainIndexTest.kt
+++ b/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainIndexTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainRepositoryTest.kt b/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainRepositoryTest.kt
index 0ab22ee..1b0caf3 100644
--- a/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainRepositoryTest.kt
+++ b/eth-repository/src/test/kotlin/net/consensys/cava/eth/repository/BlockchainRepositoryTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.eth.repository
 
diff --git a/eth/src/main/java/net/consensys/cava/eth/Address.java b/eth/src/main/java/net/consensys/cava/eth/Address.java
index ce9ece3..4e9d37f 100644
--- a/eth/src/main/java/net/consensys/cava/eth/Address.java
+++ b/eth/src/main/java/net/consensys/cava/eth/Address.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/Block.java b/eth/src/main/java/net/consensys/cava/eth/Block.java
index 3629d7e..d399370 100644
--- a/eth/src/main/java/net/consensys/cava/eth/Block.java
+++ b/eth/src/main/java/net/consensys/cava/eth/Block.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/BlockBody.java b/eth/src/main/java/net/consensys/cava/eth/BlockBody.java
index 418f4c7..77cf839 100644
--- a/eth/src/main/java/net/consensys/cava/eth/BlockBody.java
+++ b/eth/src/main/java/net/consensys/cava/eth/BlockBody.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/BlockHeader.java b/eth/src/main/java/net/consensys/cava/eth/BlockHeader.java
index 03436fe..118d3de 100644
--- a/eth/src/main/java/net/consensys/cava/eth/BlockHeader.java
+++ b/eth/src/main/java/net/consensys/cava/eth/BlockHeader.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/Hash.java b/eth/src/main/java/net/consensys/cava/eth/Hash.java
index 774a44c..236bf58 100644
--- a/eth/src/main/java/net/consensys/cava/eth/Hash.java
+++ b/eth/src/main/java/net/consensys/cava/eth/Hash.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/Log.java b/eth/src/main/java/net/consensys/cava/eth/Log.java
index a89d91f..9f3ee0e 100644
--- a/eth/src/main/java/net/consensys/cava/eth/Log.java
+++ b/eth/src/main/java/net/consensys/cava/eth/Log.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/LogsBloomFilter.java b/eth/src/main/java/net/consensys/cava/eth/LogsBloomFilter.java
index 47e8dad..4779357 100644
--- a/eth/src/main/java/net/consensys/cava/eth/LogsBloomFilter.java
+++ b/eth/src/main/java/net/consensys/cava/eth/LogsBloomFilter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/Transaction.java b/eth/src/main/java/net/consensys/cava/eth/Transaction.java
index 7058444..c9f0de2 100644
--- a/eth/src/main/java/net/consensys/cava/eth/Transaction.java
+++ b/eth/src/main/java/net/consensys/cava/eth/Transaction.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/main/java/net/consensys/cava/eth/TransactionReceipt.java b/eth/src/main/java/net/consensys/cava/eth/TransactionReceipt.java
index d37bbe0..b79f9be 100644
--- a/eth/src/main/java/net/consensys/cava/eth/TransactionReceipt.java
+++ b/eth/src/main/java/net/consensys/cava/eth/TransactionReceipt.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/BlockBodyTest.java b/eth/src/test/java/net/consensys/cava/eth/BlockBodyTest.java
index 9c43640..b1aba5a 100644
--- a/eth/src/test/java/net/consensys/cava/eth/BlockBodyTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/BlockBodyTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/BlockHeaderTest.java b/eth/src/test/java/net/consensys/cava/eth/BlockHeaderTest.java
index cc56aae..9cd6753 100644
--- a/eth/src/test/java/net/consensys/cava/eth/BlockHeaderTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/BlockHeaderTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/BlockTest.java b/eth/src/test/java/net/consensys/cava/eth/BlockTest.java
index 232a007..210bf53 100644
--- a/eth/src/test/java/net/consensys/cava/eth/BlockTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/BlockTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/LogTest.java b/eth/src/test/java/net/consensys/cava/eth/LogTest.java
index 9ceab83..fe53172 100644
--- a/eth/src/test/java/net/consensys/cava/eth/LogTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/LogTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/LogsBloomFilterTest.java b/eth/src/test/java/net/consensys/cava/eth/LogsBloomFilterTest.java
index ee5c3d0..2f35dc6 100644
--- a/eth/src/test/java/net/consensys/cava/eth/LogsBloomFilterTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/LogsBloomFilterTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/TransactionReceiptTest.java b/eth/src/test/java/net/consensys/cava/eth/TransactionReceiptTest.java
index 299154e..ad03f57 100644
--- a/eth/src/test/java/net/consensys/cava/eth/TransactionReceiptTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/TransactionReceiptTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/eth/src/test/java/net/consensys/cava/eth/TransactionTest.java b/eth/src/test/java/net/consensys/cava/eth/TransactionTest.java
index 3962550..4a0d189 100644
--- a/eth/src/test/java/net/consensys/cava/eth/TransactionTest.java
+++ b/eth/src/test/java/net/consensys/cava/eth/TransactionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/gradle/spotless.license.java b/gradle/spotless.license.java
index c894c92..f974c9a 100644
--- a/gradle/spotless.license.java
+++ b/gradle/spotless.license.java
@@ -1,12 +1,16 @@
 /*
- * Copyright $YEAR ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
- */
+ * 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.
+ */
\ No newline at end of file
diff --git a/io/src/main/java/net/consensys/cava/io/Base64.java b/io/src/main/java/net/consensys/cava/io/Base64.java
index 521a61b..4419634 100644
--- a/io/src/main/java/net/consensys/cava/io/Base64.java
+++ b/io/src/main/java/net/consensys/cava/io/Base64.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/main/java/net/consensys/cava/io/IOConsumer.java b/io/src/main/java/net/consensys/cava/io/IOConsumer.java
index 3ba9bbc..282590d 100644
--- a/io/src/main/java/net/consensys/cava/io/IOConsumer.java
+++ b/io/src/main/java/net/consensys/cava/io/IOConsumer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/main/java/net/consensys/cava/io/NullOutputStream.java b/io/src/main/java/net/consensys/cava/io/NullOutputStream.java
index c4254b6..e9ea1ec 100644
--- a/io/src/main/java/net/consensys/cava/io/NullOutputStream.java
+++ b/io/src/main/java/net/consensys/cava/io/NullOutputStream.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/main/java/net/consensys/cava/io/Resources.java b/io/src/main/java/net/consensys/cava/io/Resources.java
index 8c37c82..4f92651 100644
--- a/io/src/main/java/net/consensys/cava/io/Resources.java
+++ b/io/src/main/java/net/consensys/cava/io/Resources.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/main/java/net/consensys/cava/io/Streams.java b/io/src/main/java/net/consensys/cava/io/Streams.java
index d8f3726..3dc17c7 100644
--- a/io/src/main/java/net/consensys/cava/io/Streams.java
+++ b/io/src/main/java/net/consensys/cava/io/Streams.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/main/java/net/consensys/cava/io/file/Files.java b/io/src/main/java/net/consensys/cava/io/file/Files.java
index d342054..f65a81e 100644
--- a/io/src/main/java/net/consensys/cava/io/file/Files.java
+++ b/io/src/main/java/net/consensys/cava/io/file/Files.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/test/java/net/consensys/cava/io/Base64Test.java b/io/src/test/java/net/consensys/cava/io/Base64Test.java
index 3e277d4..01a925d 100644
--- a/io/src/test/java/net/consensys/cava/io/Base64Test.java
+++ b/io/src/test/java/net/consensys/cava/io/Base64Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/test/java/net/consensys/cava/io/ResourcesTest.java b/io/src/test/java/net/consensys/cava/io/ResourcesTest.java
index 551481f..1bf6644 100644
--- a/io/src/test/java/net/consensys/cava/io/ResourcesTest.java
+++ b/io/src/test/java/net/consensys/cava/io/ResourcesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/test/java/net/consensys/cava/io/StreamsTest.java b/io/src/test/java/net/consensys/cava/io/StreamsTest.java
index 662255c..1b767e2 100644
--- a/io/src/test/java/net/consensys/cava/io/StreamsTest.java
+++ b/io/src/test/java/net/consensys/cava/io/StreamsTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/io/src/test/java/net/consensys/cava/io/file/FilesTest.java b/io/src/test/java/net/consensys/cava/io/file/FilesTest.java
index 611ee30..26b63a1 100644
--- a/io/src/test/java/net/consensys/cava/io/file/FilesTest.java
+++ b/io/src/test/java/net/consensys/cava/io/file/FilesTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/BouncyCastleExtension.java b/junit/src/main/java/net/consensys/cava/junit/BouncyCastleExtension.java
index af88b86..f86eeb6 100644
--- a/junit/src/main/java/net/consensys/cava/junit/BouncyCastleExtension.java
+++ b/junit/src/main/java/net/consensys/cava/junit/BouncyCastleExtension.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/LuceneIndex.java b/junit/src/main/java/net/consensys/cava/junit/LuceneIndex.java
index 3aacea4..6db7ab5 100644
--- a/junit/src/main/java/net/consensys/cava/junit/LuceneIndex.java
+++ b/junit/src/main/java/net/consensys/cava/junit/LuceneIndex.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriter.java b/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriter.java
index 3576a1a..f852d24 100644
--- a/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriter.java
+++ b/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriterExtension.java b/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriterExtension.java
index d9a4dc6..6048793 100644
--- a/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriterExtension.java
+++ b/junit/src/main/java/net/consensys/cava/junit/LuceneIndexWriterExtension.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -12,14 +12,15 @@
  */
 package org.apache.tuweni.junit;
 
-import java.io.IOException;
-import java.io.UncheckedIOException;
-
 import org.apache.lucene.analysis.standard.StandardAnalyzer;
 import org.apache.lucene.index.IndexWriter;
 import org.apache.lucene.index.IndexWriterConfig;
 import org.apache.lucene.store.ByteBuffersDirectory;
 import org.apache.lucene.store.Directory;
+
+import java.io.IOException;
+import java.io.UncheckedIOException;
+
 import org.junit.jupiter.api.extension.AfterAllCallback;
 import org.junit.jupiter.api.extension.ExtensionContext;
 import org.junit.jupiter.api.extension.ParameterContext;
diff --git a/junit/src/main/java/net/consensys/cava/junit/RedisPort.java b/junit/src/main/java/net/consensys/cava/junit/RedisPort.java
index e80deb2..51e24bf 100644
--- a/junit/src/main/java/net/consensys/cava/junit/RedisPort.java
+++ b/junit/src/main/java/net/consensys/cava/junit/RedisPort.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/RedisServerExtension.java b/junit/src/main/java/net/consensys/cava/junit/RedisServerExtension.java
index 198f228..fab43e7 100644
--- a/junit/src/main/java/net/consensys/cava/junit/RedisServerExtension.java
+++ b/junit/src/main/java/net/consensys/cava/junit/RedisServerExtension.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/TempDirectory.java b/junit/src/main/java/net/consensys/cava/junit/TempDirectory.java
index 96b88c3..90f4a8d 100644
--- a/junit/src/main/java/net/consensys/cava/junit/TempDirectory.java
+++ b/junit/src/main/java/net/consensys/cava/junit/TempDirectory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/TempDirectoryExtension.java b/junit/src/main/java/net/consensys/cava/junit/TempDirectoryExtension.java
index 5a09cea..4ea6aaf 100644
--- a/junit/src/main/java/net/consensys/cava/junit/TempDirectoryExtension.java
+++ b/junit/src/main/java/net/consensys/cava/junit/TempDirectoryExtension.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/VertxExtension.java b/junit/src/main/java/net/consensys/cava/junit/VertxExtension.java
index fc6f133..65ef8ef 100644
--- a/junit/src/main/java/net/consensys/cava/junit/VertxExtension.java
+++ b/junit/src/main/java/net/consensys/cava/junit/VertxExtension.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/main/java/net/consensys/cava/junit/VertxInstance.java b/junit/src/main/java/net/consensys/cava/junit/VertxInstance.java
index 6414404..d447aa6 100644
--- a/junit/src/main/java/net/consensys/cava/junit/VertxInstance.java
+++ b/junit/src/main/java/net/consensys/cava/junit/VertxInstance.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/test/java/net/consensys/cava/junit/LuceneIndexWriterExtensionTest.java b/junit/src/test/java/net/consensys/cava/junit/LuceneIndexWriterExtensionTest.java
index beb9298..4615bd4 100644
--- a/junit/src/test/java/net/consensys/cava/junit/LuceneIndexWriterExtensionTest.java
+++ b/junit/src/test/java/net/consensys/cava/junit/LuceneIndexWriterExtensionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
@@ -18,6 +18,7 @@ import static org.junit.jupiter.api.Assertions.assertTrue;
 import org.apache.lucene.document.Document;
 import org.apache.lucene.index.IndexWriter;
 import org.apache.lucene.store.Directory;
+
 import org.junit.jupiter.api.Test;
 import org.junit.jupiter.api.extension.ExtendWith;
 
diff --git a/junit/src/test/java/net/consensys/cava/junit/RedisServerExtensionTest.java b/junit/src/test/java/net/consensys/cava/junit/RedisServerExtensionTest.java
index e94e228..03e4d84 100644
--- a/junit/src/test/java/net/consensys/cava/junit/RedisServerExtensionTest.java
+++ b/junit/src/test/java/net/consensys/cava/junit/RedisServerExtensionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/junit/src/test/java/net/consensys/cava/junit/TempDirectoryExtensionTest.java b/junit/src/test/java/net/consensys/cava/junit/TempDirectoryExtensionTest.java
index ef7e31e..c86a1ed 100644
--- a/junit/src/test/java/net/consensys/cava/junit/TempDirectoryExtensionTest.java
+++ b/junit/src/test/java/net/consensys/cava/junit/TempDirectoryExtensionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/kademlia/src/main/kotlin/net/consensys/cava/kademlia/KademliaRoutingTable.kt b/kademlia/src/main/kotlin/net/consensys/cava/kademlia/KademliaRoutingTable.kt
index 6efd83f..2299bb1 100644
--- a/kademlia/src/main/kotlin/net/consensys/cava/kademlia/KademliaRoutingTable.kt
+++ b/kademlia/src/main/kotlin/net/consensys/cava/kademlia/KademliaRoutingTable.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kademlia
 
diff --git a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/KademliaRoutingTableTest.kt b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/KademliaRoutingTableTest.kt
index 862dbdd..4d5f10b 100644
--- a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/KademliaRoutingTableTest.kt
+++ b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/KademliaRoutingTableTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kademlia
 
diff --git a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/LogarithmicDistanceTest.kt b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/LogarithmicDistanceTest.kt
index 9d3c02d..0780695 100644
--- a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/LogarithmicDistanceTest.kt
+++ b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/LogarithmicDistanceTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kademlia
 
diff --git a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/OrderedInsertTest.kt b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/OrderedInsertTest.kt
index e915abb..3571cd8 100644
--- a/kademlia/src/test/kotlin/net/consensys/cava/kademlia/OrderedInsertTest.kt
+++ b/kademlia/src/test/kotlin/net/consensys/cava/kademlia/OrderedInsertTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kademlia
 
diff --git a/kv/src/main/java/net/consensys/cava/kv/RedisBytesCodec.java b/kv/src/main/java/net/consensys/cava/kv/RedisBytesCodec.java
index 000fafc..ae611e2 100644
--- a/kv/src/main/java/net/consensys/cava/kv/RedisBytesCodec.java
+++ b/kv/src/main/java/net/consensys/cava/kv/RedisBytesCodec.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/InfinispanKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/InfinispanKeyValueStore.kt
index 4dca781..0a8eab4 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/InfinispanKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/InfinispanKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/KeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/KeyValueStore.kt
index 7a447e5..2ca24e0 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/KeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/KeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/LevelDBKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/LevelDBKeyValueStore.kt
index b3d76cc..4513dd0 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/LevelDBKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/LevelDBKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/MapDBKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/MapDBKeyValueStore.kt
index 44862da..d7934be 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/MapDBKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/MapDBKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/MapKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/MapKeyValueStore.kt
index 7989ee7..bf0f622 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/MapKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/MapKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/RedisKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/RedisKeyValueStore.kt
index 3636199..3724d1c 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/RedisKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/RedisKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/RocksDBKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/RocksDBKeyValueStore.kt
index 21d0bbc..a3dac84 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/RocksDBKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/RocksDBKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/main/kotlin/net/consensys/cava/kv/SQLKeyValueStore.kt b/kv/src/main/kotlin/net/consensys/cava/kv/SQLKeyValueStore.kt
index fa2e035..6f5b2ed 100644
--- a/kv/src/main/kotlin/net/consensys/cava/kv/SQLKeyValueStore.kt
+++ b/kv/src/main/kotlin/net/consensys/cava/kv/SQLKeyValueStore.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/kv/src/test/java/net/consensys/cava/kv/KeyValueStoreTest.java b/kv/src/test/java/net/consensys/cava/kv/KeyValueStoreTest.java
index f1671ee..202d58b 100644
--- a/kv/src/test/java/net/consensys/cava/kv/KeyValueStoreTest.java
+++ b/kv/src/test/java/net/consensys/cava/kv/KeyValueStoreTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/kv/src/test/java/net/consensys/cava/kv/RedisKeyValueStoreTest.java b/kv/src/test/java/net/consensys/cava/kv/RedisKeyValueStoreTest.java
index c31e8e9..c218a65 100644
--- a/kv/src/test/java/net/consensys/cava/kv/RedisKeyValueStoreTest.java
+++ b/kv/src/test/java/net/consensys/cava/kv/RedisKeyValueStoreTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/kv/src/test/kotlin/net/consensys/cava/kv/KeyValueStoreSpec.kt b/kv/src/test/kotlin/net/consensys/cava/kv/KeyValueStoreSpec.kt
index 585c7ca..1c46165 100644
--- a/kv/src/test/kotlin/net/consensys/cava/kv/KeyValueStoreSpec.kt
+++ b/kv/src/test/kotlin/net/consensys/cava/kv/KeyValueStoreSpec.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.kv
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/BlockBodiesMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/BlockBodiesMessage.kt
index 44fc7cf..3136b20 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/BlockBodiesMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/BlockBodiesMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/BlockHeadersMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/BlockHeadersMessage.kt
index 81402cc..7ea34cd 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/BlockHeadersMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/BlockHeadersMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/GetBlockBodiesMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/GetBlockBodiesMessage.kt
index f009c45..0ae3d73 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/GetBlockBodiesMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/GetBlockBodiesMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/GetBlockHeadersMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/GetBlockHeadersMessage.kt
index 532b330..5383deb 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/GetBlockHeadersMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/GetBlockHeadersMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/GetReceiptsMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/GetReceiptsMessage.kt
index 4d4a3ff..d6a9b5f 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/GetReceiptsMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/GetReceiptsMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/LESPeerState.kt b/les/src/main/kotlin/net/consensys/cava/les/LESPeerState.kt
index b865026..fe1935d 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/LESPeerState.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/LESPeerState.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/LESSubProtocolHandler.kt b/les/src/main/kotlin/net/consensys/cava/les/LESSubProtocolHandler.kt
index fdc25b9..1548573 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/LESSubProtocolHandler.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/LESSubProtocolHandler.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/LESSubprotocol.kt b/les/src/main/kotlin/net/consensys/cava/les/LESSubprotocol.kt
index 9b2b643..28eb42c 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/LESSubprotocol.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/LESSubprotocol.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/LightClient.kt b/les/src/main/kotlin/net/consensys/cava/les/LightClient.kt
index 11d544f..75394aa 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/LightClient.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/LightClient.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/ReceiptsMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/ReceiptsMessage.kt
index e0c2a07..cc6c601 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/ReceiptsMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/ReceiptsMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/main/kotlin/net/consensys/cava/les/StatusMessage.kt b/les/src/main/kotlin/net/consensys/cava/les/StatusMessage.kt
index ade38b2..e36931a 100644
--- a/les/src/main/kotlin/net/consensys/cava/les/StatusMessage.kt
+++ b/les/src/main/kotlin/net/consensys/cava/les/StatusMessage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/test/kotlin/net/consensys/cava/les/LESSubProtocolHandlerTest.kt b/les/src/test/kotlin/net/consensys/cava/les/LESSubProtocolHandlerTest.kt
index ffda803..0c40377 100644
--- a/les/src/test/kotlin/net/consensys/cava/les/LESSubProtocolHandlerTest.kt
+++ b/les/src/test/kotlin/net/consensys/cava/les/LESSubProtocolHandlerTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/test/kotlin/net/consensys/cava/les/LESSubprotocolTest.kt b/les/src/test/kotlin/net/consensys/cava/les/LESSubprotocolTest.kt
index ed7283d..a3438b9 100644
--- a/les/src/test/kotlin/net/consensys/cava/les/LESSubprotocolTest.kt
+++ b/les/src/test/kotlin/net/consensys/cava/les/LESSubprotocolTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/les/src/test/kotlin/net/consensys/cava/les/MessagesTest.kt b/les/src/test/kotlin/net/consensys/cava/les/MessagesTest.kt
index 5ef5f99..27e68fb 100644
--- a/les/src/test/kotlin/net/consensys/cava/les/MessagesTest.kt
+++ b/les/src/test/kotlin/net/consensys/cava/les/MessagesTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2019 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.les
 
diff --git a/merkle-trie/src/main/java/net/consensys/cava/trie/CompactEncoding.java b/merkle-trie/src/main/java/net/consensys/cava/trie/CompactEncoding.java
index 863bbcd..f606b1f 100644
--- a/merkle-trie/src/main/java/net/consensys/cava/trie/CompactEncoding.java
+++ b/merkle-trie/src/main/java/net/consensys/cava/trie/CompactEncoding.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/BranchNode.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/BranchNode.kt
index 8433ec5..223fe39 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/BranchNode.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/BranchNode.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/DefaultNodeFactory.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/DefaultNodeFactory.kt
index c01fb3d..a9342cb 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/DefaultNodeFactory.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/DefaultNodeFactory.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/ExtensionNode.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/ExtensionNode.kt
index fac849d..597a02c 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/ExtensionNode.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/ExtensionNode.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/GetVisitor.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/GetVisitor.kt
index b5787d8..7bc5df3 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/GetVisitor.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/GetVisitor.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/LeafNode.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/LeafNode.kt
index 9f739f6..81e82d3 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/LeafNode.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/LeafNode.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerklePatriciaTrie.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerklePatriciaTrie.kt
index fb7a617..2a46d60 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerklePatriciaTrie.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerklePatriciaTrie.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorage.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorage.kt
index e1da35d..1f5ad30 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorage.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorage.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorageException.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorageException.kt
index 26eb23f..ae6fc4c 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorageException.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleStorageException.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleTrie.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleTrie.kt
index 25317c0..6696bf7 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleTrie.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/MerkleTrie.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/Node.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/Node.kt
index 39e746a..42209b2 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/Node.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/Node.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeFactory.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeFactory.kt
index 138067c..48be691 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeFactory.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeFactory.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeVisitor.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeVisitor.kt
index 1ebd1f3..c874f54 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeVisitor.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NodeVisitor.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NullNode.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NullNode.kt
index f1f54b4..c0961db 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NullNode.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/NullNode.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/PutVisitor.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/PutVisitor.kt
index 9f4bbec..c466dc6 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/PutVisitor.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/PutVisitor.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/RemoveVisitor.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/RemoveVisitor.kt
index fc78951..b5e50c9 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/RemoveVisitor.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/RemoveVisitor.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrie.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrie.kt
index 5932bf7..216d1a2 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrie.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrie.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNode.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNode.kt
index 3567e89..6d6868c 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNode.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNode.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNodeFactory.kt b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNodeFactory.kt
index 8fadf86..c313395 100644
--- a/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNodeFactory.kt
+++ b/merkle-trie/src/main/kotlin/net/consensys/cava/trie/StoredNodeFactory.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/test/java/net/consensys/cava/trie/CompactEncodingTest.java b/merkle-trie/src/test/java/net/consensys/cava/trie/CompactEncodingTest.java
index 05c95e2..2ab0446 100644
--- a/merkle-trie/src/test/java/net/consensys/cava/trie/CompactEncodingTest.java
+++ b/merkle-trie/src/test/java/net/consensys/cava/trie/CompactEncodingTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTrieJavaTest.java b/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTrieJavaTest.java
index 0191945..b752ffb 100644
--- a/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTrieJavaTest.java
+++ b/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTrieJavaTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTriePerformanceTest.java b/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTriePerformanceTest.java
index bcacfac..cc6dbdd 100644
--- a/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTriePerformanceTest.java
+++ b/merkle-trie/src/test/java/net/consensys/cava/trie/MerklePatriciaTriePerformanceTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/merkle-trie/src/test/java/net/consensys/cava/trie/StoredMerklePatriciaTrieJavaTest.java b/merkle-trie/src/test/java/net/consensys/cava/trie/StoredMerklePatriciaTrieJavaTest.java
index b75fd2b..5e3daf6 100644
--- a/merkle-trie/src/test/java/net/consensys/cava/trie/StoredMerklePatriciaTrieJavaTest.java
+++ b/merkle-trie/src/test/java/net/consensys/cava/trie/StoredMerklePatriciaTrieJavaTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/merkle-trie/src/test/kotlin/net/consensys/cava/trie/MerklePatriciaTrieKotlinTest.kt b/merkle-trie/src/test/kotlin/net/consensys/cava/trie/MerklePatriciaTrieKotlinTest.kt
index 1573044..45c5902 100644
--- a/merkle-trie/src/test/kotlin/net/consensys/cava/trie/MerklePatriciaTrieKotlinTest.kt
+++ b/merkle-trie/src/test/kotlin/net/consensys/cava/trie/MerklePatriciaTrieKotlinTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/merkle-trie/src/test/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrieKotlinTest.kt b/merkle-trie/src/test/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrieKotlinTest.kt
index ccd64c1..3b510f5 100644
--- a/merkle-trie/src/test/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrieKotlinTest.kt
+++ b/merkle-trie/src/test/kotlin/net/consensys/cava/trie/StoredMerklePatriciaTrieKotlinTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.trie
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineByteChannel.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineByteChannel.kt
index 55766d2..41d87f6 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineByteChannel.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineByteChannel.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroup.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroup.kt
index c4ac4f3..f0bb475 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroup.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroup.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannel.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannel.kt
index 73eba14..7563cac 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannel.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannel.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineNetworkChannel.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineNetworkChannel.kt
index ff82a42..9a6788f 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineNetworkChannel.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineNetworkChannel.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSelector.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSelector.kt
index 82acf44..13cb285 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSelector.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSelector.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineServerSocketChannel.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineServerSocketChannel.kt
index 3ee3dd6..6eb24e6 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineServerSocketChannel.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineServerSocketChannel.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannel.kt b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannel.kt
index 11141c4..41ed43a 100644
--- a/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannel.kt
+++ b/net-coroutines/src/main/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannel.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/test/java/net/consensys/cava/net/coroutines/SelectorTest.java b/net-coroutines/src/test/java/net/consensys/cava/net/coroutines/SelectorTest.java
index 3e2ed10..7df159c 100644
--- a/net-coroutines/src/test/java/net/consensys/cava/net/coroutines/SelectorTest.java
+++ b/net-coroutines/src/test/java/net/consensys/cava/net/coroutines/SelectorTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroupTest.kt b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroupTest.kt
index 630087b..a25b8b4 100644
--- a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroupTest.kt
+++ b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineChannelGroupTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannelTest.kt b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannelTest.kt
index 3a8d0a7..b8acdaa 100644
--- a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannelTest.kt
+++ b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineDatagramChannelTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSelectorTest.kt b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSelectorTest.kt
index e1a948e..63c533e 100644
--- a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSelectorTest.kt
+++ b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSelectorTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannelTest.kt b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannelTest.kt
index 7764abf..559059a 100644
--- a/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannelTest.kt
+++ b/net-coroutines/src/test/kotlin/net/consensys/cava/net/coroutines/CoroutineSocketChannelTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.net.coroutines
 
diff --git a/net/src/main/java/net/consensys/cava/net/tls/ClientFingerprintTrustManager.java b/net/src/main/java/net/consensys/cava/net/tls/ClientFingerprintTrustManager.java
index dc8f365..d701b51 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/ClientFingerprintTrustManager.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/ClientFingerprintTrustManager.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/DelegatingTrustManagerFactory.java b/net/src/main/java/net/consensys/cava/net/tls/DelegatingTrustManagerFactory.java
index 68bf5ab..2f5e0ed 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/DelegatingTrustManagerFactory.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/DelegatingTrustManagerFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/FileBackedFingerprintRepository.java b/net/src/main/java/net/consensys/cava/net/tls/FileBackedFingerprintRepository.java
index fb75c77..3f39bf4 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/FileBackedFingerprintRepository.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/FileBackedFingerprintRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/FingerprintRepository.java b/net/src/main/java/net/consensys/cava/net/tls/FingerprintRepository.java
index 952b26c..927a585 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/FingerprintRepository.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/FingerprintRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/ServerFingerprintTrustManager.java b/net/src/main/java/net/consensys/cava/net/tls/ServerFingerprintTrustManager.java
index c1270da..174d04c 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/ServerFingerprintTrustManager.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/ServerFingerprintTrustManager.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/SingleTrustManagerFactory.java b/net/src/main/java/net/consensys/cava/net/tls/SingleTrustManagerFactory.java
index 2f9c820..e6f633b 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/SingleTrustManagerFactory.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/SingleTrustManagerFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/TLS.java b/net/src/main/java/net/consensys/cava/net/tls/TLS.java
index d81b7dd..b90fadf 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/TLS.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/TLS.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/TLSEnvironmentException.java b/net/src/main/java/net/consensys/cava/net/tls/TLSEnvironmentException.java
index 91d0202..d84cc06 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/TLSEnvironmentException.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/TLSEnvironmentException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactories.java b/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactories.java
index ccb22cf..2062f1d 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactories.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactories.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactoryWrapper.java b/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactoryWrapper.java
index 642a9fd..cede1e4 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactoryWrapper.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/TrustManagerFactoryWrapper.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/main/java/net/consensys/cava/net/tls/VertxTrustOptions.java b/net/src/main/java/net/consensys/cava/net/tls/VertxTrustOptions.java
index 35156c1..cc64b02 100644
--- a/net/src/main/java/net/consensys/cava/net/tls/VertxTrustOptions.java
+++ b/net/src/main/java/net/consensys/cava/net/tls/VertxTrustOptions.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrRecordTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrRecordTest.java
index 9d8b0a8..8026ff6 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrRecordTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrRecordTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrTofuTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrTofuTest.java
index 421ca68..d7bbfc4 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrTofuTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrTofuTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrWhitelistTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrWhitelistTest.java
index 21c0ce0..26f42de 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrWhitelistTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientCaOrWhitelistTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientRecordTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientRecordTest.java
index b34d1fd..6f46429 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientRecordTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientRecordTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientTofuTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientTofuTest.java
index 12ab3cc..b0764f5 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientTofuTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientTofuTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ClientWhitelistTest.java b/net/src/test/java/net/consensys/cava/net/tls/ClientWhitelistTest.java
index e436d37..9067fba 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ClientWhitelistTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ClientWhitelistTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/FileBackedFingerprintRepositoryTest.java b/net/src/test/java/net/consensys/cava/net/tls/FileBackedFingerprintRepositoryTest.java
index 9edf535..b9731d5 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/FileBackedFingerprintRepositoryTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/FileBackedFingerprintRepositoryTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/InsecureTrustOptions.java b/net/src/test/java/net/consensys/cava/net/tls/InsecureTrustOptions.java
index 04a434f..18cdfb9 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/InsecureTrustOptions.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/InsecureTrustOptions.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/SecurityTestUtils.java b/net/src/test/java/net/consensys/cava/net/tls/SecurityTestUtils.java
index 40e60e0..6057e62 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/SecurityTestUtils.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/SecurityTestUtils.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrRecordTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrRecordTest.java
index ffb87d2..312e36b 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrRecordTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrRecordTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrTofaTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrTofaTest.java
index eca35f1..2776d96 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrTofaTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrTofaTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrWhitelistTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrWhitelistTest.java
index ac54cf7..9c44c04 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrWhitelistTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerCaOrWhitelistTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerRecordTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerRecordTest.java
index d0a919a..b9ba0c9 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerRecordTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerRecordTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerTofaTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerTofaTest.java
index 7ba3124..d268ab8 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerTofaTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerTofaTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/ServerWhitelistTest.java b/net/src/test/java/net/consensys/cava/net/tls/ServerWhitelistTest.java
index 72c9e75..3cd226d 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/ServerWhitelistTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/ServerWhitelistTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/net/src/test/java/net/consensys/cava/net/tls/TLSTest.java b/net/src/test/java/net/consensys/cava/net/tls/TLSTest.java
index e583819..52288e5 100644
--- a/net/src/test/java/net/consensys/cava/net/tls/TLSTest.java
+++ b/net/src/test/java/net/consensys/cava/net/tls/TLSTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/EphemeralPeerRepository.java b/plumtree/src/main/java/net/consensys/cava/plumtree/EphemeralPeerRepository.java
index 529ea63..f75c2d8 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/EphemeralPeerRepository.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/EphemeralPeerRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/MessageHashing.java b/plumtree/src/main/java/net/consensys/cava/plumtree/MessageHashing.java
index 1026507..3257c61 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/MessageHashing.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/MessageHashing.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/MessageSender.java b/plumtree/src/main/java/net/consensys/cava/plumtree/MessageSender.java
index bd3a100..01aac1a 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/MessageSender.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/MessageSender.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/Peer.java b/plumtree/src/main/java/net/consensys/cava/plumtree/Peer.java
index 652daa7..bf42d86 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/Peer.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/Peer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/PeerRepository.java b/plumtree/src/main/java/net/consensys/cava/plumtree/PeerRepository.java
index 057e8a6..9f0419c 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/PeerRepository.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/PeerRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/State.java b/plumtree/src/main/java/net/consensys/cava/plumtree/State.java
index 0e5e569..36ecd37 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/State.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/State.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/StateActor.java b/plumtree/src/main/java/net/consensys/cava/plumtree/StateActor.java
index b4c4350..dc5029d 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/StateActor.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/StateActor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/main/java/net/consensys/cava/plumtree/StateActorFactory.java b/plumtree/src/main/java/net/consensys/cava/plumtree/StateActorFactory.java
index d83ed72..61d076b 100644
--- a/plumtree/src/main/java/net/consensys/cava/plumtree/StateActorFactory.java
+++ b/plumtree/src/main/java/net/consensys/cava/plumtree/StateActorFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/plumtree/src/test/java/net/consensys/cava/plumtree/StateTest.java b/plumtree/src/test/java/net/consensys/cava/plumtree/StateTest.java
index a70b91f..ef4cade 100644
--- a/plumtree/src/test/java/net/consensys/cava/plumtree/StateTest.java
+++ b/plumtree/src/test/java/net/consensys/cava/plumtree/StateTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/AccumulatingRLPWriter.java b/rlp/src/main/java/net/consensys/cava/rlp/AccumulatingRLPWriter.java
index a63985b..3c903c9 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/AccumulatingRLPWriter.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/AccumulatingRLPWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/ByteBufferRLPWriter.java b/rlp/src/main/java/net/consensys/cava/rlp/ByteBufferRLPWriter.java
index 6d8b9a5..9a646ab 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/ByteBufferRLPWriter.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/ByteBufferRLPWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPReader.java b/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPReader.java
index 2158dd4..d96b012 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPReader.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPReader.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPWriter.java b/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPWriter.java
index be80f68..ed658b5 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPWriter.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/BytesRLPWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/DelegatingRLPWriter.java b/rlp/src/main/java/net/consensys/cava/rlp/DelegatingRLPWriter.java
index 4d8fb68..252c258 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/DelegatingRLPWriter.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/DelegatingRLPWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/EndOfRLPException.java b/rlp/src/main/java/net/consensys/cava/rlp/EndOfRLPException.java
index 8874067..88648e6 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/EndOfRLPException.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/EndOfRLPException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPEncodingException.java b/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPEncodingException.java
index 4963021..9d872d7 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPEncodingException.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPEncodingException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPTypeException.java b/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPTypeException.java
index fc832b6..dc512e4 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPTypeException.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/InvalidRLPTypeException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/RLP.java b/rlp/src/main/java/net/consensys/cava/rlp/RLP.java
index 593f2c8..39b0e92 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/RLP.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/RLP.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/RLPException.java b/rlp/src/main/java/net/consensys/cava/rlp/RLPException.java
index 956b890..ce22a59 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/RLPException.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/RLPException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/RLPReader.java b/rlp/src/main/java/net/consensys/cava/rlp/RLPReader.java
index 259b0df..f9cc643 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/RLPReader.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/RLPReader.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/main/java/net/consensys/cava/rlp/RLPWriter.java b/rlp/src/main/java/net/consensys/cava/rlp/RLPWriter.java
index 0a3fb43..b7675af 100644
--- a/rlp/src/main/java/net/consensys/cava/rlp/RLPWriter.java
+++ b/rlp/src/main/java/net/consensys/cava/rlp/RLPWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/test/java/net/consensys/cava/rlp/ByteBufferWriterTest.java b/rlp/src/test/java/net/consensys/cava/rlp/ByteBufferWriterTest.java
index 226177c..3597317 100644
--- a/rlp/src/test/java/net/consensys/cava/rlp/ByteBufferWriterTest.java
+++ b/rlp/src/test/java/net/consensys/cava/rlp/ByteBufferWriterTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPReaderTest.java b/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPReaderTest.java
index 5df20a4..dfed5e0 100644
--- a/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPReaderTest.java
+++ b/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPReaderTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPWriterTest.java b/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPWriterTest.java
index cf6cc72..24b6a0b 100644
--- a/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPWriterTest.java
+++ b/rlp/src/test/java/net/consensys/cava/rlp/BytesRLPWriterTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/EthereumIESEncryptionEngine.java b/rlpx/src/main/java/net/consensys/cava/rlpx/EthereumIESEncryptionEngine.java
index bb7afe2..20c59cf 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/EthereumIESEncryptionEngine.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/EthereumIESEncryptionEngine.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/HandshakeMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/HandshakeMessage.java
index 29c9d9a..253244a 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/HandshakeMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/HandshakeMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/InitiatorHandshakeMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/InitiatorHandshakeMessage.java
index ef5e601..63ea49b 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/InitiatorHandshakeMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/InitiatorHandshakeMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/InvalidMACException.java b/rlpx/src/main/java/net/consensys/cava/rlpx/InvalidMACException.java
index 20fd4a5..d488bde 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/InvalidMACException.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/InvalidMACException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/MemoryWireConnectionsRepository.java b/rlpx/src/main/java/net/consensys/cava/rlpx/MemoryWireConnectionsRepository.java
index 7c2ba46..d80cd52 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/MemoryWireConnectionsRepository.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/MemoryWireConnectionsRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnection.java b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnection.java
index 0bba653..1cb7a47 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnection.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnection.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnectionFactory.java b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnectionFactory.java
index 2c7ab36..2b4be34 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnectionFactory.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxConnectionFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxMessage.java
index 5e47aed..dc87eaf 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxService.java b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxService.java
index 72d2603..f4ecce9 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxService.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/RLPxService.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/ResponderHandshakeMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/ResponderHandshakeMessage.java
index b0343e1..fceafb0 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/ResponderHandshakeMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/ResponderHandshakeMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/WireConnectionRepository.java b/rlpx/src/main/java/net/consensys/cava/rlpx/WireConnectionRepository.java
index 45827be..beb9240 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/WireConnectionRepository.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/WireConnectionRepository.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/vertx/VertxRLPxService.java b/rlpx/src/main/java/net/consensys/cava/rlpx/vertx/VertxRLPxService.java
index 2ecb989..a5bb2f8 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/vertx/VertxRLPxService.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/vertx/VertxRLPxService.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/Capability.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/Capability.java
index e763418..b82b5df 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/Capability.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/Capability.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultSubProtocolIdentifier.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultSubProtocolIdentifier.java
index adaa68f..c67447d 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultSubProtocolIdentifier.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultSubProtocolIdentifier.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultWireConnection.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultWireConnection.java
index 1c64e26..628d5b5 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultWireConnection.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DefaultWireConnection.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectMessage.java
index 2d3b2ad..fdb1f0f 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectReason.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectReason.java
index fe1b959..b44b446 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectReason.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/DisconnectReason.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/HelloMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/HelloMessage.java
index 06b9f2a..823763d 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/HelloMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/HelloMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PingMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PingMessage.java
index 5edd7e3..5b01c6b 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PingMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PingMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PongMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PongMessage.java
index 3b955b1..1239ef1 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PongMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/PongMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocol.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocol.java
index aea446b..535a478 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocol.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocol.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolHandler.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolHandler.java
index 4018c75..b9fe122 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolHandler.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolHandler.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolIdentifier.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolIdentifier.java
index 7d11c67..0daf1d9 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolIdentifier.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/SubProtocolIdentifier.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireConnection.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireConnection.java
index f9376af..3efeda7 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireConnection.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireConnection.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireProtocolMessage.java b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireProtocolMessage.java
index e5e87e4..532100f 100644
--- a/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireProtocolMessage.java
+++ b/rlpx/src/main/java/net/consensys/cava/rlpx/wire/WireProtocolMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/RLPxConnectionFactoryTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/RLPxConnectionFactoryTest.java
index ec38ae6..adf3d9a 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/RLPxConnectionFactoryTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/RLPxConnectionFactoryTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxAcceptanceTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxAcceptanceTest.java
index 501a53f..4486bf6 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxAcceptanceTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxAcceptanceTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxRLPxServiceTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxRLPxServiceTest.java
index c715afe..2725f03 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxRLPxServiceTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/vertx/VertxRLPxServiceTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DefaultWireConnectionTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DefaultWireConnectionTest.java
index eb271da..0e0617a 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DefaultWireConnectionTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DefaultWireConnectionTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DisconnectMessageTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DisconnectMessageTest.java
index 780fc7e..762bb8f 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DisconnectMessageTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/DisconnectMessageTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/HelloMessageTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/HelloMessageTest.java
index 8ce6bbe..2e02635 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/HelloMessageTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/HelloMessageTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/PingPongTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/PingPongTest.java
index 10a2000..fc9a3d0 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/PingPongTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/PingPongTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/RLPxConnectionMessageExchangeTest.java b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/RLPxConnectionMessageExchangeTest.java
index 548cd90..d37baba 100644
--- a/rlpx/src/test/java/net/consensys/cava/rlpx/wire/RLPxConnectionMessageExchangeTest.java
+++ b/rlpx/src/test/java/net/consensys/cava/rlpx/wire/RLPxConnectionMessageExchangeTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentity.java b/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentity.java
index 65a9691..e10fc86 100644
--- a/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentity.java
+++ b/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryService.java b/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryService.java
index c04e2cc..0a696cb 100644
--- a/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryService.java
+++ b/scuttlebutt-discovery/src/main/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryService.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentityTest.java b/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentityTest.java
index 65bdbe7..2838827 100644
--- a/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentityTest.java
+++ b/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/LocalIdentityTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java b/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
index f5af1a5..e399cfb 100644
--- a/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
+++ b/scuttlebutt-discovery/src/test/java/net/consensys/cava/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/HandshakeException.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/HandshakeException.java
index 4f1ac41..81725d5 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/HandshakeException.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/HandshakeException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClient.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClient.java
index c4b3bc3..f07a428 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClient.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClient.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeServer.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeServer.java
index 1d5df38..5362971 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeServer.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeServer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStream.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStream.java
index 91632d6..f28080d 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStream.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStream.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamClient.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamClient.java
index 3db0ad8..ab5d006 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamClient.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamClient.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamServer.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamServer.java
index 07cd41b..fe8dae8 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamServer.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamServer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/StreamException.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/StreamException.java
index e70179a..49056ca 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/StreamException.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/StreamException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandler.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandler.java
index c0e0cc8..ba3c95a 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandler.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandler.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandlerFactory.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandlerFactory.java
index 048bd2b..e947f49 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandlerFactory.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ClientHandlerFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxClient.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxClient.java
index ffc1492..c7f69e5 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxClient.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxClient.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxServer.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxServer.java
index fce6768..abd8b82 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxServer.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/SecureScuttlebuttVertxServer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandler.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandler.java
index b5a9277..b51bfe5 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandler.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandler.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandlerFactory.java b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandlerFactory.java
index e50baa8..cf9aaf8 100644
--- a/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandlerFactory.java
+++ b/scuttlebutt-handshake/src/main/java/net/consensys/cava/scuttlebutt/handshake/vertx/ServerHandlerFactory.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClientTest.java b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClientTest.java
index 3870ee6..f79b0af 100644
--- a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClientTest.java
+++ b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttHandshakeClientTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamTest.java b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamTest.java
index 93b052c..cbcffab 100644
--- a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamTest.java
+++ b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/SecureScuttlebuttStreamTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/vertx/VertxIntegrationTest.java b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
index 84f8780..754477e 100644
--- a/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
+++ b/scuttlebutt-handshake/src/test/java/net/consensys/cava/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCCodec.java b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCCodec.java
index bf63217..ca7223d 100644
--- a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCCodec.java
+++ b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCCodec.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCFlag.java b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCFlag.java
index 3ab2088..574a9d8 100644
--- a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCFlag.java
+++ b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCFlag.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCMessage.java b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCMessage.java
index 3cb7553..a82f1fc 100644
--- a/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCMessage.java
+++ b/scuttlebutt-rpc/src/main/java/net/consensys/cava/scuttlebutt/rpc/RPCMessage.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/PatchworkIntegrationTest.java b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/PatchworkIntegrationTest.java
index 4e8ef97..8495d2c 100644
--- a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/PatchworkIntegrationTest.java
+++ b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/PatchworkIntegrationTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCEncodingTest.java b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCEncodingTest.java
index 872118b..10966cf 100644
--- a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCEncodingTest.java
+++ b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCEncodingTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCFlagTest.java b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCFlagTest.java
index 4a50ec1..dd5efde 100644
--- a/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCFlagTest.java
+++ b/scuttlebutt-rpc/src/test/java/net/consensys/cava/scuttlebutt/rpc/RPCFlagTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519KeyPairIdentity.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519KeyPairIdentity.java
index fcc9173..e9c7948 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519KeyPairIdentity.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519KeyPairIdentity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519PublicKeyIdentity.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519PublicKeyIdentity.java
index 300e51a..72a58e3 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519PublicKeyIdentity.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Ed25519PublicKeyIdentity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Identity.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Identity.java
index 5bcdcce..ecdc1d3 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Identity.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Identity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Invite.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Invite.java
index 2b17fcd..6857d55 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Invite.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/Invite.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1KeyPairIdentity.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1KeyPairIdentity.java
index 9b11bee..18a563c 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1KeyPairIdentity.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1KeyPairIdentity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1PublicKeyIdentity.java b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1PublicKeyIdentity.java
index 1868bd9..86aa066 100644
--- a/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1PublicKeyIdentity.java
+++ b/scuttlebutt/src/main/java/net/consensys/cava/scuttlebutt/SECP256K1PublicKeyIdentity.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/IdentityTest.java b/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/IdentityTest.java
index 036138f..b3f0b36 100644
--- a/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/IdentityTest.java
+++ b/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/IdentityTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/InviteTest.java b/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/InviteTest.java
index ef7a7c6..b745b9b 100644
--- a/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/InviteTest.java
+++ b/scuttlebutt/src/test/java/net/consensys/cava/scuttlebutt/InviteTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/ByteBufferSSZWriter.java b/ssz/src/main/java/net/consensys/cava/ssz/ByteBufferSSZWriter.java
index 9de08a1..9540973 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/ByteBufferSSZWriter.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/ByteBufferSSZWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZReader.java b/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZReader.java
index 6516d64..58fa3f5 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZReader.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZReader.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZWriter.java b/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZWriter.java
index 397b358..4ccda97 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZWriter.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/BytesSSZWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/EndOfSSZException.java b/ssz/src/main/java/net/consensys/cava/ssz/EndOfSSZException.java
index d40bbb8..51534d4 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/EndOfSSZException.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/EndOfSSZException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/InvalidSSZTypeException.java b/ssz/src/main/java/net/consensys/cava/ssz/InvalidSSZTypeException.java
index c6fdc72..5460cdb 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/InvalidSSZTypeException.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/InvalidSSZTypeException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/SSZ.java b/ssz/src/main/java/net/consensys/cava/ssz/SSZ.java
index f1a62af..fd93aa5 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/SSZ.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/SSZ.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/SSZException.java b/ssz/src/main/java/net/consensys/cava/ssz/SSZException.java
index bdc876f..49d0656 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/SSZException.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/SSZException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/SSZReader.java b/ssz/src/main/java/net/consensys/cava/ssz/SSZReader.java
index f82722b..436f77e 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/SSZReader.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/SSZReader.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/java/net/consensys/cava/ssz/SSZWriter.java b/ssz/src/main/java/net/consensys/cava/ssz/SSZWriter.java
index 0ee7e82..bf5f9f9 100644
--- a/ssz/src/main/java/net/consensys/cava/ssz/SSZWriter.java
+++ b/ssz/src/main/java/net/consensys/cava/ssz/SSZWriter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZReader.kt b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZReader.kt
index 23a5310..92a662c 100644
--- a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZReader.kt
+++ b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZReader.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZWriter.kt b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZWriter.kt
index 218786c..9622e2d 100644
--- a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZWriter.kt
+++ b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/BytesSSZWriter.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZ.kt b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZ.kt
index 28ef22d..7fefddc 100644
--- a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZ.kt
+++ b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZ.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZReader.kt b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZReader.kt
index 7c0954b..def15c3 100644
--- a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZReader.kt
+++ b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZReader.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZWriter.kt b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZWriter.kt
index 11b9e9c..d103592 100644
--- a/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZWriter.kt
+++ b/ssz/src/main/kotlin/net/consensys/cava/ssz/experimental/SSZWriter.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/ssz/src/test/java/net/consensys/cava/ssz/ByteBufferWriterTest.java b/ssz/src/test/java/net/consensys/cava/ssz/ByteBufferWriterTest.java
index ae9392f..5e84ff0 100644
--- a/ssz/src/test/java/net/consensys/cava/ssz/ByteBufferWriterTest.java
+++ b/ssz/src/test/java/net/consensys/cava/ssz/ByteBufferWriterTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZReaderTest.java b/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZReaderTest.java
index c2eec4f..ac3f7d5 100644
--- a/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZReaderTest.java
+++ b/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZReaderTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZWriterTest.java b/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZWriterTest.java
index e0ddf3b..758cc0c 100644
--- a/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZWriterTest.java
+++ b/ssz/src/test/java/net/consensys/cava/ssz/BytesSSZWriterTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/test/java/net/consensys/cava/ssz/HashTreeRootTest.java b/ssz/src/test/java/net/consensys/cava/ssz/HashTreeRootTest.java
index 1ea9ea8..f414c07 100644
--- a/ssz/src/test/java/net/consensys/cava/ssz/HashTreeRootTest.java
+++ b/ssz/src/test/java/net/consensys/cava/ssz/HashTreeRootTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2019 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/ssz/src/test/kotlin/net/consensys/cava/ssz/experimental/SSZTest.kt b/ssz/src/test/kotlin/net/consensys/cava/ssz/experimental/SSZTest.kt
index 6ec0115..8d5f64f 100644
--- a/ssz/src/test/kotlin/net/consensys/cava/ssz/experimental/SSZTest.kt
+++ b/ssz/src/test/kotlin/net/consensys/cava/ssz/experimental/SSZTest.kt
@@ -1,14 +1,18 @@
 /*
- * Copyright 2018 ConsenSys AG.
+ * Licensed 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
  *
- * Licensed 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
  *
- * 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.
+ * 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.tuweni.ssz.experimental
 
diff --git a/toml/src/main/java/net/consensys/cava/toml/AccumulatingErrorListener.java b/toml/src/main/java/net/consensys/cava/toml/AccumulatingErrorListener.java
index 05dc52b..35b1b28 100644
--- a/toml/src/main/java/net/consensys/cava/toml/AccumulatingErrorListener.java
+++ b/toml/src/main/java/net/consensys/cava/toml/AccumulatingErrorListener.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/ArrayVisitor.java b/toml/src/main/java/net/consensys/cava/toml/ArrayVisitor.java
index bd9cb0d..cff43bd 100644
--- a/toml/src/main/java/net/consensys/cava/toml/ArrayVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/ArrayVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/ErrorReporter.java b/toml/src/main/java/net/consensys/cava/toml/ErrorReporter.java
index 458e000..feff860 100644
--- a/toml/src/main/java/net/consensys/cava/toml/ErrorReporter.java
+++ b/toml/src/main/java/net/consensys/cava/toml/ErrorReporter.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/InlineTableVisitor.java b/toml/src/main/java/net/consensys/cava/toml/InlineTableVisitor.java
index 22de053..300a2b9 100644
--- a/toml/src/main/java/net/consensys/cava/toml/InlineTableVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/InlineTableVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/JsonSerializer.java b/toml/src/main/java/net/consensys/cava/toml/JsonSerializer.java
index 1b1d59f..8865c2e 100644
--- a/toml/src/main/java/net/consensys/cava/toml/JsonSerializer.java
+++ b/toml/src/main/java/net/consensys/cava/toml/JsonSerializer.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/KeyVisitor.java b/toml/src/main/java/net/consensys/cava/toml/KeyVisitor.java
index 2cc1d33..9bb1a88 100644
--- a/toml/src/main/java/net/consensys/cava/toml/KeyVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/KeyVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/LineVisitor.java b/toml/src/main/java/net/consensys/cava/toml/LineVisitor.java
index 71cffc0..895f0ab 100644
--- a/toml/src/main/java/net/consensys/cava/toml/LineVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/LineVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/LocalDateVisitor.java b/toml/src/main/java/net/consensys/cava/toml/LocalDateVisitor.java
index 3dcab41..5751771 100644
--- a/toml/src/main/java/net/consensys/cava/toml/LocalDateVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/LocalDateVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/LocalTimeVisitor.java b/toml/src/main/java/net/consensys/cava/toml/LocalTimeVisitor.java
index 7a38523..a1ef470 100644
--- a/toml/src/main/java/net/consensys/cava/toml/LocalTimeVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/LocalTimeVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/MutableTomlArray.java b/toml/src/main/java/net/consensys/cava/toml/MutableTomlArray.java
index 72a9cdb..3fe1941 100644
--- a/toml/src/main/java/net/consensys/cava/toml/MutableTomlArray.java
+++ b/toml/src/main/java/net/consensys/cava/toml/MutableTomlArray.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/MutableTomlTable.java b/toml/src/main/java/net/consensys/cava/toml/MutableTomlTable.java
index b3e1f4d..19eebdb 100644
--- a/toml/src/main/java/net/consensys/cava/toml/MutableTomlTable.java
+++ b/toml/src/main/java/net/consensys/cava/toml/MutableTomlTable.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/Parser.java b/toml/src/main/java/net/consensys/cava/toml/Parser.java
index 24de490..cc5e5b2 100644
--- a/toml/src/main/java/net/consensys/cava/toml/Parser.java
+++ b/toml/src/main/java/net/consensys/cava/toml/Parser.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/QuotedStringVisitor.java b/toml/src/main/java/net/consensys/cava/toml/QuotedStringVisitor.java
index ff55658..389b2bb 100644
--- a/toml/src/main/java/net/consensys/cava/toml/QuotedStringVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/QuotedStringVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TokenName.java b/toml/src/main/java/net/consensys/cava/toml/TokenName.java
index 744a8fd..bdf22e0 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TokenName.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TokenName.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/Toml.java b/toml/src/main/java/net/consensys/cava/toml/Toml.java
index d4b2def..5f76343 100644
--- a/toml/src/main/java/net/consensys/cava/toml/Toml.java
+++ b/toml/src/main/java/net/consensys/cava/toml/Toml.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlArray.java b/toml/src/main/java/net/consensys/cava/toml/TomlArray.java
index 94c92c5..d5d8368 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlArray.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlArray.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlInvalidTypeException.java b/toml/src/main/java/net/consensys/cava/toml/TomlInvalidTypeException.java
index d62e685..f7aaa2a 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlInvalidTypeException.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlInvalidTypeException.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlParseError.java b/toml/src/main/java/net/consensys/cava/toml/TomlParseError.java
index 933872a..d1d2530 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlParseError.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlParseError.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlParseResult.java b/toml/src/main/java/net/consensys/cava/toml/TomlParseResult.java
index 30c0449..4d92124 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlParseResult.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlParseResult.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlPosition.java b/toml/src/main/java/net/consensys/cava/toml/TomlPosition.java
index 3f8d796..12d6b84 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlPosition.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlPosition.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlTable.java b/toml/src/main/java/net/consensys/cava/toml/TomlTable.java
index 72e482c..e6fd2c2 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlTable.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlTable.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlType.java b/toml/src/main/java/net/consensys/cava/toml/TomlType.java
index a77071e..0f01697 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlType.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlType.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/TomlVersion.java b/toml/src/main/java/net/consensys/cava/toml/TomlVersion.java
index d360aa9..940a207 100644
--- a/toml/src/main/java/net/consensys/cava/toml/TomlVersion.java
+++ b/toml/src/main/java/net/consensys/cava/toml/TomlVersion.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/ValueVisitor.java b/toml/src/main/java/net/consensys/cava/toml/ValueVisitor.java
index 3a51f68..027efc3 100644
--- a/toml/src/main/java/net/consensys/cava/toml/ValueVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/ValueVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/main/java/net/consensys/cava/toml/ZoneOffsetVisitor.java b/toml/src/main/java/net/consensys/cava/toml/ZoneOffsetVisitor.java
index 882ee1f..3024134 100644
--- a/toml/src/main/java/net/consensys/cava/toml/ZoneOffsetVisitor.java
+++ b/toml/src/main/java/net/consensys/cava/toml/ZoneOffsetVisitor.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/test/java/net/consensys/cava/toml/MutableTomlArrayTest.java b/toml/src/test/java/net/consensys/cava/toml/MutableTomlArrayTest.java
index a8c4726..4e91ad7 100644
--- a/toml/src/test/java/net/consensys/cava/toml/MutableTomlArrayTest.java
+++ b/toml/src/test/java/net/consensys/cava/toml/MutableTomlArrayTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/test/java/net/consensys/cava/toml/MutableTomlTableTest.java b/toml/src/test/java/net/consensys/cava/toml/MutableTomlTableTest.java
index e99908c..562bbde 100644
--- a/toml/src/test/java/net/consensys/cava/toml/MutableTomlTableTest.java
+++ b/toml/src/test/java/net/consensys/cava/toml/MutableTomlTableTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/test/java/net/consensys/cava/toml/TokenNameTest.java b/toml/src/test/java/net/consensys/cava/toml/TokenNameTest.java
index 2150abf..6b4d0c3 100644
--- a/toml/src/test/java/net/consensys/cava/toml/TokenNameTest.java
+++ b/toml/src/test/java/net/consensys/cava/toml/TokenNameTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/toml/src/test/java/net/consensys/cava/toml/TomlTest.java b/toml/src/test/java/net/consensys/cava/toml/TomlTest.java
index a240af3..a29a819 100644
--- a/toml/src/test/java/net/consensys/cava/toml/TomlTest.java
+++ b/toml/src/test/java/net/consensys/cava/toml/TomlTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt256Value.java b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt256Value.java
index f5720d2..208db08 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt256Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt256Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt384Value.java b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt384Value.java
index ff27cde..5dd53c7 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt384Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt384Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt64Value.java b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt64Value.java
index 39afc45..ba11019 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt64Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/BaseUInt64Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt256.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt256.java
index 476c0fd..57799a1 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt256.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt256.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt256Domain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt256Domain.java
index 10800f5..8d8c188 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt256Domain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt256Domain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt256Value.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt256Value.java
index cf1bad0..af993cc 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt256Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt256Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt256ValueDomain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt256ValueDomain.java
index 47f88b3..79166b6 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt256ValueDomain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt256ValueDomain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt256s.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt256s.java
index 2173390..53a26ad 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt256s.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt256s.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt384.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt384.java
index 62b0983..9707844 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt384.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt384.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt384Domain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt384Domain.java
index 5c2287f..fe08115 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt384Domain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt384Domain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt384Value.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt384Value.java
index b0b74a8..b788ff0 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt384Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt384Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt384ValueDomain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt384ValueDomain.java
index a5fb1bb..ae3d5d7 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt384ValueDomain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt384ValueDomain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt384s.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt384s.java
index 828ce45..c5e8d3e 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt384s.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt384s.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt64.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt64.java
index 9577e08..0d2dda4 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt64.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt64.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt64Domain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt64Domain.java
index 6734fc6..ccdeb69 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt64Domain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt64Domain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt64Value.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt64Value.java
index d8b71e9..159a3dd 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt64Value.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt64Value.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt64ValueDomain.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt64ValueDomain.java
index 3025494..c0ede0a 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt64ValueDomain.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt64ValueDomain.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/bigints/UInt64s.java b/units/src/main/java/net/consensys/cava/units/bigints/UInt64s.java
index b1648e1..692e1a1 100644
--- a/units/src/main/java/net/consensys/cava/units/bigints/UInt64s.java
+++ b/units/src/main/java/net/consensys/cava/units/bigints/UInt64s.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/ethereum/Gas.java b/units/src/main/java/net/consensys/cava/units/ethereum/Gas.java
index 3c6d335..8e0aa66 100644
--- a/units/src/main/java/net/consensys/cava/units/ethereum/Gas.java
+++ b/units/src/main/java/net/consensys/cava/units/ethereum/Gas.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/main/java/net/consensys/cava/units/ethereum/Wei.java b/units/src/main/java/net/consensys/cava/units/ethereum/Wei.java
index 03331ed..e430561 100644
--- a/units/src/main/java/net/consensys/cava/units/ethereum/Wei.java
+++ b/units/src/main/java/net/consensys/cava/units/ethereum/Wei.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt256ValueTest.java b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt256ValueTest.java
index 26b97f5..b00c464 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt256ValueTest.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt256ValueTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt384ValueTest.java b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt384ValueTest.java
index 3e99c86..757ab9f 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt384ValueTest.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt384ValueTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt64ValueTest.java b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt64ValueTest.java
index b912a1b..6960a74 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt64ValueTest.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/BaseUInt64ValueTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/UInt256Test.java b/units/src/test/java/net/consensys/cava/units/bigints/UInt256Test.java
index db16eec..36eb1d1 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/UInt256Test.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/UInt256Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/UInt384Test.java b/units/src/test/java/net/consensys/cava/units/bigints/UInt384Test.java
index 2033ca5..9c26313 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/UInt384Test.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/UInt384Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/bigints/UInt64Test.java b/units/src/test/java/net/consensys/cava/units/bigints/UInt64Test.java
index a3a8534..3f8caa3 100644
--- a/units/src/test/java/net/consensys/cava/units/bigints/UInt64Test.java
+++ b/units/src/test/java/net/consensys/cava/units/bigints/UInt64Test.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/ethereum/GasTest.java b/units/src/test/java/net/consensys/cava/units/ethereum/GasTest.java
index 2203463..f09abcd 100644
--- a/units/src/test/java/net/consensys/cava/units/ethereum/GasTest.java
+++ b/units/src/test/java/net/consensys/cava/units/ethereum/GasTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *
diff --git a/units/src/test/java/net/consensys/cava/units/ethereum/WeiTest.java b/units/src/test/java/net/consensys/cava/units/ethereum/WeiTest.java
index 6ad0d8b..bfdb1ed 100644
--- a/units/src/test/java/net/consensys/cava/units/ethereum/WeiTest.java
+++ b/units/src/test/java/net/consensys/cava/units/ethereum/WeiTest.java
@@ -1,8 +1,8 @@
 /*
- * Copyright 2018 ConsenSys AG.
- *
- * Licensed 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
+ * Licensed 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
  *


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@tuweni.apache.org
For additional commands, e-mail: commits-help@tuweni.apache.org