You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pekko.apache.org by fa...@apache.org on 2023/02/20 22:42:25 UTC

[incubator-pekko-connectors] branch main updated: add apache license headers (#30)

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

fanningpj pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-pekko-connectors.git


The following commit(s) were added to refs/heads/main by this push:
     new 51808c49 add apache license headers (#30)
51808c49 is described below

commit 51808c4924317169d8da8e6ebf02aaef4fda150f
Author: PJ Fanning <pj...@users.noreply.github.com>
AuthorDate: Mon Feb 20 23:42:19 2023 +0100

    add apache license headers (#30)
    
    * add apache licenses
    
    * scalafmt
---
 .../alpakka/amqp/AmqpConnectionProvider.scala      |  9 +++
 .../alpakka/amqp/AmqpConnectorSettings.scala       |  9 +++
 .../impl/AbstractAmqpAsyncFlowStageLogic.scala     |  9 +++
 .../amqp/impl/AbstractAmqpFlowStageLogic.scala     |  9 +++
 .../alpakka/amqp/impl/AmqpAsyncFlowStage.scala     |  9 +++
 .../amqp/impl/AmqpAsyncUnorderedFlowStage.scala    |  9 +++
 .../alpakka/amqp/impl/AmqpConnectorLogic.scala     |  9 +++
 .../alpakka/amqp/impl/AmqpReplyToSinkStage.scala   |  9 +++
 .../alpakka/amqp/impl/AmqpRpcFlowStage.scala       |  9 +++
 .../alpakka/amqp/impl/AmqpSimpleFlowStage.scala    |  9 +++
 .../stream/alpakka/amqp/impl/AmqpSourceStage.scala |  9 +++
 .../stream/alpakka/amqp/javadsl/AmqpFlow.scala     |  9 +++
 .../alpakka/amqp/javadsl/AmqpFlowWithContext.scala |  9 +++
 .../stream/alpakka/amqp/javadsl/AmqpRpcFlow.scala  |  9 +++
 .../stream/alpakka/amqp/javadsl/AmqpSink.scala     |  9 +++
 .../stream/alpakka/amqp/javadsl/AmqpSource.scala   |  9 +++
 .../amqp/javadsl/CommittableReadResult.scala       |  9 +++
 .../scala/akka/stream/alpakka/amqp/model.scala     |  9 +++
 .../stream/alpakka/amqp/scaladsl/AmqpFlow.scala    |  9 +++
 .../amqp/scaladsl/AmqpFlowWithContext.scala        |  9 +++
 .../stream/alpakka/amqp/scaladsl/AmqpRpcFlow.scala |  9 +++
 .../stream/alpakka/amqp/scaladsl/AmqpSink.scala    |  9 +++
 .../stream/alpakka/amqp/scaladsl/AmqpSource.scala  |  9 +++
 .../amqp/scaladsl/CommittableReadResult.scala      |  9 +++
 .../alpakka/avroparquet/impl/AvroParquetFlow.scala |  9 +++
 .../avroparquet/impl/AvroParquetSource.scala       |  9 +++
 .../avroparquet/javadsl/AvroParquetFlow.scala      |  9 +++
 .../avroparquet/javadsl/AvroParquetSink.scala      |  9 +++
 .../avroparquet/javadsl/AvroParquetSource.scala    |  9 +++
 .../avroparquet/scaladsl/AvroParquetFlow.scala     |  9 +++
 .../avroparquet/scaladsl/AvroParquetSink.scala     |  9 +++
 .../avroparquet/scaladsl/AvroParquetSource.scala   |  9 +++
 .../eventbridge/EventBridgePublishSettings.scala   |  9 +++
 .../eventbridge/javadsl/EventBridgePublisher.scala |  9 +++
 .../scaladsl/EventBridgePublisher.scala            |  9 +++
 .../alpakka/awslambda/javadsl/AwsLambdaFlow.scala  |  9 +++
 .../alpakka/awslambda/scaladsl/AwsLambdaFlow.scala |  9 +++
 .../impl/AzureQueueSinkFunctions.scala             |  9 +++
 .../storagequeue/impl/AzureQueueSourceStage.scala  |  9 +++
 .../storagequeue/javadsl/AzureQueueSink.scala      |  9 +++
 .../storagequeue/javadsl/AzureQueueSource.scala    |  9 +++
 .../stream/alpakka/azure/storagequeue/model.scala  |  9 +++
 .../storagequeue/scaladsl/AzureQueueSink.scala     |  9 +++
 .../storagequeue/scaladsl/AzureQueueSource.scala   |  9 +++
 .../alpakka/azure/storagequeue/settings.scala      |  9 +++
 .../cassandra/AkkaDiscoverySessionProvider.scala   |  9 +++
 .../cassandra/CassandraMetricsRegistry.scala       |  9 +++
 .../cassandra/CassandraServerMetaData.scala        |  9 +++
 .../cassandra/CassandraSessionSettings.scala       |  9 +++
 .../alpakka/cassandra/CassandraWriteSettings.scala |  9 +++
 .../alpakka/cassandra/CqlSessionProvider.scala     |  9 +++
 .../cassandra/DriverConfigLoaderFromConfig.scala   |  9 +++
 .../alpakka/cassandra/javadsl/CassandraFlow.scala  |  9 +++
 .../cassandra/javadsl/CassandraSession.scala       |  9 +++
 .../javadsl/CassandraSessionRegistry.scala         |  9 +++
 .../cassandra/javadsl/CassandraSource.scala        |  9 +++
 .../alpakka/cassandra/scaladsl/CassandraFlow.scala |  9 +++
 .../cassandra/scaladsl/CassandraSession.scala      |  9 +++
 .../scaladsl/CassandraSessionRegistry.scala        |  9 +++
 .../cassandra/scaladsl/CassandraSource.scala       |  9 +++
 .../couchbase/javadsl/DiscoverySupport.java        |  9 +++
 .../couchbase/CouchbaseResponseException.scala     |  9 +++
 .../couchbase/CouchbaseSessionRegistry.scala       |  9 +++
 .../couchbase/impl/CouchbaseClusterRegistry.scala  |  9 +++
 .../couchbase/impl/CouchbaseSessionImpl.scala      |  9 +++
 .../impl/CouchbaseSessionJavaAdapter.scala         |  9 +++
 .../alpakka/couchbase/impl/RxUtilities.scala       |  9 +++
 .../alpakka/couchbase/javadsl/CouchbaseFlow.scala  |  9 +++
 .../couchbase/javadsl/CouchbaseSession.scala       |  9 +++
 .../alpakka/couchbase/javadsl/CouchbaseSink.scala  |  9 +++
 .../couchbase/javadsl/CouchbaseSource.scala        |  9 +++
 .../akka/stream/alpakka/couchbase/model.scala      |  9 +++
 .../alpakka/couchbase/scaladsl/CouchbaseFlow.scala |  9 +++
 .../couchbase/scaladsl/CouchbaseSession.scala      |  9 +++
 .../alpakka/couchbase/scaladsl/CouchbaseSink.scala |  9 +++
 .../couchbase/scaladsl/CouchbaseSource.scala       |  9 +++
 .../couchbase/scaladsl/DiscoverySupport.scala      |  9 +++
 .../stream/alpakka/csv/javadsl/ByteOrderMark.java  |  9 +++
 .../stream/alpakka/csv/javadsl/CsvFormatting.java  |  9 +++
 .../stream/alpakka/csv/javadsl/CsvParsing.java     |  9 +++
 .../alpakka/csv/javadsl/CsvQuotingStyle.java       |  9 +++
 .../akka/stream/alpakka/csv/javadsl/CsvToMap.java  |  9 +++
 .../stream/alpakka/csv/impl/CsvFormatter.scala     |  9 +++
 .../akka/stream/alpakka/csv/impl/CsvParser.scala   |  9 +++
 .../stream/alpakka/csv/impl/CsvParsingStage.scala  |  9 +++
 .../alpakka/csv/impl/CsvToMapJavaStage.scala       |  9 +++
 .../stream/alpakka/csv/impl/CsvToMapStage.scala    |  9 +++
 .../main/scala/akka/stream/alpakka/csv/model.scala |  9 +++
 .../alpakka/csv/scaladsl/ByteOrderMark.scala       |  9 +++
 .../alpakka/csv/scaladsl/CsvFormatting.scala       |  9 +++
 .../stream/alpakka/csv/scaladsl/CsvParsing.scala   |  9 +++
 .../alpakka/csv/scaladsl/CsvQuotingStyle.scala     |  9 +++
 .../stream/alpakka/csv/scaladsl/CsvToMap.scala     |  9 +++
 .../akka/stream/alpakka/dynamodb/DynamoDbOp.scala  |  9 +++
 .../stream/alpakka/dynamodb/javadsl/DynamoDb.scala |  9 +++
 .../alpakka/dynamodb/scaladsl/DynamoDb.scala       |  9 +++
 .../stream/alpakka/elasticsearch/ApiVersion.java   |  9 +++
 .../alpakka/elasticsearch/ApiVersionBase.java      |  9 +++
 .../elasticsearch/OpensearchApiVersion.java        |  9 +++
 .../ElasticsearchConnectionSettings.scala          |  9 +++
 .../elasticsearch/ElasticsearchParams.scala        |  9 +++
 .../ElasticsearchSourceSettings.scala              |  9 +++
 .../elasticsearch/ElasticsearchWriteSettings.scala |  9 +++
 .../OpensearchConnectionSettings.scala             |  9 +++
 .../alpakka/elasticsearch/OpensearchParams.scala   |  9 +++
 .../elasticsearch/OpensearchSourceSettings.scala   |  9 +++
 .../elasticsearch/OpensearchWriteSettings.scala    |  9 +++
 .../stream/alpakka/elasticsearch/ReadResult.scala  |  9 +++
 .../alpakka/elasticsearch/SourceSettingsBase.scala |  9 +++
 .../alpakka/elasticsearch/WriteMessage.scala       |  9 +++
 .../alpakka/elasticsearch/WriteSettingsBase.scala  |  9 +++
 .../elasticsearch/impl/ElasticsearchApi.scala      |  9 +++
 .../impl/ElasticsearchSimpleFlowStage.scala        |  9 +++
 .../impl/ElasticsearchSourceStage.scala            |  9 +++
 .../elasticsearch/impl/NDJsonProtocol.scala        |  9 +++
 .../alpakka/elasticsearch/impl/RestBulkApi.scala   |  9 +++
 .../alpakka/elasticsearch/impl/RestBulkApiV5.scala |  9 +++
 .../alpakka/elasticsearch/impl/RestBulkApiV7.scala |  9 +++
 .../elasticsearch/javadsl/ElasticsearchFlow.scala  |  9 +++
 .../elasticsearch/javadsl/ElasticsearchSink.scala  |  9 +++
 .../javadsl/ElasticsearchSource.scala              |  9 +++
 .../elasticsearch/scaladsl/ElasticsearchFlow.scala | 13 +++-
 .../elasticsearch/scaladsl/ElasticsearchSink.scala |  9 +++
 .../scaladsl/ElasticsearchSource.scala             |  9 +++
 .../elasticsearch/testkit/MessageFactory.scala     |  9 +++
 .../akka/stream/alpakka/file/DirectoryChange.java  |  9 +++
 .../alpakka/file/impl/DirectoryChangesSource.java  |  9 +++
 .../stream/alpakka/file/impl/FileTailSource.java   |  9 +++
 .../stream/alpakka/file/javadsl/Directory.java     |  9 +++
 .../file/javadsl/DirectoryChangesSource.java       |  9 +++
 .../alpakka/file/javadsl/FileTailSource.java       |  9 +++
 .../file/impl/archive/EnsureByteStreamSize.scala   |  9 +++
 .../impl/archive/FileByteStringSeparators.scala    |  9 +++
 .../file/impl/archive/TarArchiveEntry.scala        |  9 +++
 .../file/impl/archive/TarArchiveManager.scala      |  9 +++
 .../alpakka/file/impl/archive/TarReaderStage.scala |  9 +++
 .../alpakka/file/impl/archive/ZipArchiveFlow.scala |  9 +++
 .../file/impl/archive/ZipArchiveManager.scala      |  9 +++
 .../file/impl/archive/ZipReaderSource.scala        |  9 +++
 .../akka/stream/alpakka/file/javadsl/Archive.scala |  9 +++
 .../alpakka/file/javadsl/LogRotatorSink.scala      |  9 +++
 .../scala/akka/stream/alpakka/file/model.scala     |  9 +++
 .../stream/alpakka/file/scaladsl/Archive.scala     |  9 +++
 .../stream/alpakka/file/scaladsl/Directory.scala   |  9 +++
 .../file/scaladsl/DirectoryChangesSource.scala     |  9 +++
 .../alpakka/file/scaladsl/FileTailSource.scala     |  9 +++
 .../alpakka/file/scaladsl/LogRotatorSink.scala     |  9 +++
 .../alpakka/ftp/impl/CommonFtpOperations.scala     |  9 +++
 .../alpakka/ftp/impl/FtpBrowserGraphStage.scala    |  9 +++
 .../impl/FtpDirectoryOperationsGraphStage.scala    |  9 +++
 .../stream/alpakka/ftp/impl/FtpGraphStage.scala    |  9 +++
 .../alpakka/ftp/impl/FtpGraphStageLogic.scala      |  9 +++
 .../stream/alpakka/ftp/impl/FtpIOGraphStage.scala  |  9 +++
 .../akka/stream/alpakka/ftp/impl/FtpLike.scala     |  9 +++
 .../stream/alpakka/ftp/impl/FtpOperations.scala    |  9 +++
 .../stream/alpakka/ftp/impl/FtpSourceFactory.scala |  9 +++
 .../stream/alpakka/ftp/impl/FtpsOperations.scala   |  9 +++
 .../stream/alpakka/ftp/impl/SftpOperations.scala   |  9 +++
 .../akka/stream/alpakka/ftp/javadsl/FtpApi.scala   |  9 +++
 .../main/scala/akka/stream/alpakka/ftp/model.scala |  9 +++
 .../akka/stream/alpakka/ftp/scaladsl/FtpApi.scala  |  9 +++
 .../akka/stream/alpakka/geode/javadsl/Geode.java   |  9 +++
 .../geode/javadsl/GeodeWithPoolSubscription.java   |  9 +++
 .../stream/alpakka/geode/AkkaPdxSerializer.scala   |  9 +++
 .../akka/stream/alpakka/geode/GeodeSettings.scala  |  9 +++
 .../stream/alpakka/geode/impl/GeodeCache.scala     |  9 +++
 .../alpakka/geode/impl/GeodeCapabilities.scala     |  9 +++
 .../geode/impl/pdx/DelegatingPdxSerializer.scala   |  9 +++
 .../stream/alpakka/geode/impl/pdx/PdxDecoder.scala |  9 +++
 .../stream/alpakka/geode/impl/pdx/PdxEncoder.scala |  9 +++
 .../geode/impl/pdx/ShapelessPdxSerializer.scala    |  9 +++
 .../geode/impl/stage/GeodeCQueryGraphLogic.scala   |  9 +++
 .../impl/stage/GeodeContinuousSourceStage.scala    |  9 +++
 .../geode/impl/stage/GeodeFiniteSourceStage.scala  |  9 +++
 .../alpakka/geode/impl/stage/GeodeFlowStage.scala  |  9 +++
 .../geode/impl/stage/GeodeQueryGraphLogic.scala    |  9 +++
 .../geode/impl/stage/GeodeSourceStageLogic.scala   |  9 +++
 .../akka/stream/alpakka/geode/scaladsl/Geode.scala |  9 +++
 .../bigquery/storage/BigQueryRecordMapImpl.scala   |  9 +++
 .../bigquery/storage/BigQueryStorageSettings.scala |  9 +++
 .../bigquery/storage/ProtobufConverters.scala      |  9 +++
 .../bigquery/storage/impl/AkkaGrpcSettings.scala   |  9 +++
 .../bigquery/storage/impl/ArrowSource.scala        |  9 +++
 .../bigquery/storage/impl/AvroDecoder.scala        |  9 +++
 .../bigquery/storage/impl/AvroSource.scala         |  9 +++
 .../bigquery/storage/impl/SDKClientSource.scala    |  9 +++
 .../storage/javadsl/BigQueryArrowStorage.scala     |  9 +++
 .../storage/javadsl/BigQueryAvroStorage.scala      |  9 +++
 .../bigquery/storage/javadsl/BigQueryStorage.scala |  9 +++
 .../storage/scaladsl/BigQueryArrowStorage.scala    |  9 +++
 .../storage/scaladsl/BigQueryAvroStorage.scala     |  9 +++
 .../storage/scaladsl/BigQueryStorage.scala         |  9 +++
 .../scaladsl/BigQueryStorageAttributes.scala       |  9 +++
 .../scaladsl/GrpcBigQueryStorageReader.scala       |  9 +++
 .../googlecloud/bigquery/BigQueryAttributes.scala  |  9 +++
 .../googlecloud/bigquery/BigQueryEndpoints.scala   |  9 +++
 .../googlecloud/bigquery/BigQueryException.scala   |  9 +++
 .../alpakka/googlecloud/bigquery/BigQueryExt.scala |  9 +++
 .../googlecloud/bigquery/BigQuerySettings.scala    |  9 +++
 .../bigquery/InsertAllRetryPolicy.scala            |  9 +++
 .../googlecloud/bigquery/javadsl/BigQuery.scala    |  9 +++
 .../javadsl/jackson/BigQueryMarshallers.scala      |  9 +++
 .../bigquery/model/DatasetJsonProtocol.scala       |  9 +++
 .../bigquery/model/ErrorProtoJsonProtocol.scala    |  9 +++
 .../bigquery/model/JobJsonProtocol.scala           |  9 +++
 .../bigquery/model/QueryJsonProtocol.scala         |  9 +++
 .../googlecloud/bigquery/model/StringEnum.scala    |  9 +++
 .../bigquery/model/TableDataJsonProtocol.scala     |  9 +++
 .../bigquery/model/TableJsonProtocol.scala         |  9 +++
 .../googlecloud/bigquery/scaladsl/BigQuery.scala   |  9 +++
 .../bigquery/scaladsl/BigQueryDatasets.scala       |  9 +++
 .../bigquery/scaladsl/BigQueryJobs.scala           |  9 +++
 .../bigquery/scaladsl/BigQueryQueries.scala        |  9 +++
 .../bigquery/scaladsl/BigQueryRest.scala           |  9 +++
 .../bigquery/scaladsl/BigQueryTableData.scala      |  9 +++
 .../bigquery/scaladsl/BigQueryTables.scala         |  9 +++
 .../bigquery/scaladsl/schema/BasicSchemas.scala    |  9 +++
 .../bigquery/scaladsl/schema/BigQuerySchemas.scala |  9 +++
 .../scaladsl/schema/CollectionSchemas.scala        |  9 +++
 .../bigquery/scaladsl/schema/JavaTimeSchemas.scala |  9 +++
 .../scaladsl/schema/PrimitiveSchemaWriter.scala    |  9 +++
 .../bigquery/scaladsl/schema/ProductSchemas.scala  |  9 +++
 .../bigquery/scaladsl/schema/Schema.scala          |  9 +++
 .../bigquery/scaladsl/schema/SchemaWriter.scala    |  9 +++
 .../bigquery/scaladsl/schema/StandardSchemas.scala |  9 +++
 .../scaladsl/spray/BigQueryBasicFormats.scala      |  9 +++
 .../bigquery/scaladsl/spray/BigQueryBytes.scala    |  9 +++
 .../scaladsl/spray/BigQueryCollectionFormats.scala |  9 +++
 .../scaladsl/spray/BigQueryJavaTimeFormats.scala   |  9 +++
 .../scaladsl/spray/BigQueryJsonFormat.scala        |  9 +++
 .../scaladsl/spray/BigQueryJsonProtocol.scala      |  9 +++
 .../bigquery/scaladsl/spray/BigQueryNumber.scala   |  9 +++
 .../scaladsl/spray/BigQueryProductFormats.scala    |  9 +++
 .../scaladsl/spray/BigQueryRestBasicFormats.scala  |  9 +++
 .../scaladsl/spray/BigQueryRestJsonProtocol.scala  |  9 +++
 .../scaladsl/spray/BigQueryStandardFormats.scala   |  9 +++
 .../googlecloud/pubsub/grpc/PubSubSettings.scala   |  9 +++
 .../pubsub/grpc/impl/AkkaGrpcSettings.scala        |  9 +++
 .../pubsub/grpc/impl/DeprecatedCredentials.scala   |  9 +++
 .../pubsub/grpc/javadsl/GooglePubSub.scala         |  9 +++
 .../pubsub/grpc/javadsl/GrpcPublisher.scala        |  9 +++
 .../pubsub/grpc/javadsl/GrpcSubscriber.scala       |  9 +++
 .../pubsub/grpc/javadsl/PubSubAttributes.scala     |  9 +++
 .../pubsub/grpc/scaladsl/GooglePubSub.scala        |  9 +++
 .../pubsub/grpc/scaladsl/GrpcPublisher.scala       |  9 +++
 .../pubsub/grpc/scaladsl/GrpcSubscriber.scala      |  9 +++
 .../pubsub/grpc/scaladsl/PubSubAttributes.scala    |  9 +++
 .../googlecloud/pubsub/impl/PubSubApi.scala        |  9 +++
 .../googlecloud/pubsub/javadsl/GooglePubSub.scala  |  9 +++
 .../stream/alpakka/googlecloud/pubsub/model.scala  |  9 +++
 .../googlecloud/pubsub/scaladsl/GooglePubSub.scala |  9 +++
 .../alpakka/googlecloud/storage/Bucket.scala       |  9 +++
 .../googlecloud/storage/CustomerEncryption.scala   |  9 +++
 .../alpakka/googlecloud/storage/FailedUpload.scala |  9 +++
 .../googlecloud/storage/GCSAttributes.scala        |  9 +++
 .../alpakka/googlecloud/storage/GCSExt.scala       |  9 +++
 .../googlecloud/storage/GCStorageAttributes.scala  |  9 +++
 .../alpakka/googlecloud/storage/GCStorageExt.scala |  9 +++
 .../googlecloud/storage/GCStorageSettings.scala    |  9 +++
 .../googlecloud/storage/ObjectAccessControls.scala |  9 +++
 .../storage/ObjectNotFoundException.scala          |  9 +++
 .../stream/alpakka/googlecloud/storage/Owner.scala |  9 +++
 .../alpakka/googlecloud/storage/ProjectTeam.scala  |  9 +++
 .../googlecloud/storage/StorageObject.scala        |  9 +++
 .../googlecloud/storage/StorageSettings.scala      |  9 +++
 .../googlecloud/storage/impl/BucketInfo.scala      |  9 +++
 .../storage/impl/BucketListResult.scala            |  9 +++
 .../alpakka/googlecloud/storage/impl/Formats.scala |  9 +++
 .../googlecloud/storage/impl/GCStorageStream.scala |  9 +++
 .../googlecloud/storage/impl/MultiPartUpload.scala |  9 +++
 .../googlecloud/storage/impl/RewriteResponse.scala |  9 +++
 .../storage/impl/UploadPartResponse.scala          |  9 +++
 .../googlecloud/storage/javadsl/GCStorage.scala    |  9 +++
 .../googlecloud/storage/scaladsl/GCStorage.scala   |  9 +++
 .../alpakka/googlecloud/storage/settings.scala     |  9 +++
 .../alpakka/google/javadsl/XUploadContentType.java |  9 +++
 .../stream/alpakka/google/GoogleAttributes.scala   |  9 +++
 .../akka/stream/alpakka/google/GoogleExt.scala     |  9 +++
 .../stream/alpakka/google/GoogleSettings.scala     |  9 +++
 .../stream/alpakka/google/PaginatedRequest.scala   |  9 +++
 .../stream/alpakka/google/ResumableUpload.scala    |  9 +++
 .../stream/alpakka/google/auth/AccessToken.scala   |  9 +++
 .../google/auth/ComputeEngineCredentials.scala     |  9 +++
 .../stream/alpakka/google/auth/Credentials.scala   |  9 +++
 .../google/auth/GoogleComputeMetadata.scala        |  9 +++
 .../stream/alpakka/google/auth/GoogleOAuth2.scala  |  9 +++
 .../google/auth/GoogleOAuth2Credentials.scala      |  9 +++
 .../google/auth/GoogleOAuth2Exception.scala        |  9 +++
 .../stream/alpakka/google/auth/NoCredentials.scala |  9 +++
 .../alpakka/google/auth/OAuth2Credentials.scala    |  9 +++
 .../google/auth/ServiceAccountCredentials.scala    |  9 +++
 .../google/auth/UserAccessCredentials.scala        |  9 +++
 .../alpakka/google/auth/UserAccessMetadata.scala   |  9 +++
 .../google/http/ForwardProxyHttpsContext.scala     |  9 +++
 .../google/http/ForwardProxyPoolSettings.scala     |  9 +++
 .../stream/alpakka/google/http/GoogleHttp.scala    |  9 +++
 .../akka/stream/alpakka/google/implicits.scala     |  9 +++
 .../stream/alpakka/google/javadsl/Google.scala     |  9 +++
 .../stream/alpakka/google/javadsl/Paginated.scala  |  9 +++
 .../stream/alpakka/google/scaladsl/Google.scala    |  9 +++
 .../stream/alpakka/google/scaladsl/Paginated.scala |  9 +++
 .../google/scaladsl/`X-Upload-Content-Type`.scala  |  9 +++
 .../stream/alpakka/google/util/AnnotateLast.scala  |  9 +++
 .../stream/alpakka/google/util/EitherFlow.scala    |  9 +++
 .../akka/stream/alpakka/google/util/Retry.scala    |  9 +++
 .../firebase/fcm/FcmNotificationModels.scala       |  9 +++
 .../alpakka/google/firebase/fcm/FcmSettings.scala  |  9 +++
 .../google/firebase/fcm/impl/FcmFlows.scala        |  9 +++
 .../google/firebase/fcm/impl/FcmJsonSupport.scala  |  9 +++
 .../google/firebase/fcm/impl/FcmSender.scala       |  9 +++
 .../google/firebase/fcm/javadsl/GoogleFcm.scala    |  9 +++
 .../google/firebase/fcm/scaladsl/GoogleFcm.scala   |  9 +++
 .../google/firebase/fcm/v1/impl/FcmFlows.scala     |  9 +++
 .../firebase/fcm/v1/impl/FcmJsonSupport.scala      |  9 +++
 .../google/firebase/fcm/v1/impl/FcmSender.scala    |  9 +++
 .../google/firebase/fcm/v1/javadsl/GoogleFcm.scala |  9 +++
 .../firebase/fcm/v1/models/AndroidConfig.scala     |  9 +++
 .../google/firebase/fcm/v1/models/ApnsConfig.scala |  9 +++
 .../firebase/fcm/v1/models/BasicNotification.scala |  9 +++
 .../firebase/fcm/v1/models/FcmNotification.scala   |  9 +++
 .../google/firebase/fcm/v1/models/FcmOption.scala  |  9 +++
 .../firebase/fcm/v1/models/FcmResponse.scala       |  9 +++
 .../fcm/v1/models/NotificationTarget.scala         |  9 +++
 .../firebase/fcm/v1/models/WebPushConfig.scala     |  9 +++
 .../firebase/fcm/v1/scaladsl/GoogleFcm.scala       |  9 +++
 .../akka/stream/alpakka/hbase/HTableSettings.scala |  9 +++
 .../alpakka/hbase/impl/HBaseCapabilities.scala     |  9 +++
 .../stream/alpakka/hbase/impl/HBaseFlowStage.scala |  9 +++
 .../alpakka/hbase/impl/HBaseSourceStage.scala      |  9 +++
 .../stream/alpakka/hbase/javadsl/HTableStage.scala |  9 +++
 .../alpakka/hbase/scaladsl/HTableStage.scala       |  9 +++
 .../stream/alpakka/hdfs/impl/HdfsFlowStage.scala   |  9 +++
 .../impl/strategy/DefaultRotationStrategy.scala    |  9 +++
 .../hdfs/impl/strategy/DefaultSyncStrategy.scala   |  9 +++
 .../alpakka/hdfs/impl/strategy/Strategy.scala      |  9 +++
 .../hdfs/impl/writer/CompressedDataWriter.scala    |  9 +++
 .../alpakka/hdfs/impl/writer/DataWriter.scala      |  9 +++
 .../alpakka/hdfs/impl/writer/HdfsWriter.scala      |  9 +++
 .../alpakka/hdfs/impl/writer/SequenceWriter.scala  |  9 +++
 .../stream/alpakka/hdfs/javadsl/HdfsFlow.scala     |  9 +++
 .../stream/alpakka/hdfs/javadsl/HdfsSource.scala   |  9 +++
 .../scala/akka/stream/alpakka/hdfs/model.scala     |  9 +++
 .../stream/alpakka/hdfs/scaladsl/HdfsFlow.scala    |  9 +++
 .../stream/alpakka/hdfs/scaladsl/HdfsSource.scala  |  9 +++
 .../huawei/pushkit/ForwardProxyHttpsContext.scala  |  9 +++
 .../huawei/pushkit/ForwardProxyPoolSettings.scala  |  9 +++
 .../alpakka/huawei/pushkit/HmsSettingExt.scala     |  9 +++
 .../alpakka/huawei/pushkit/HmsSettings.scala       |  9 +++
 .../alpakka/huawei/pushkit/impl/HmsSession.scala   |  9 +++
 .../alpakka/huawei/pushkit/impl/HmsTokenApi.scala  |  9 +++
 .../alpakka/huawei/pushkit/impl/PushKitFlows.scala |  9 +++
 .../huawei/pushkit/impl/PushKitJsonSupport.scala   |  9 +++
 .../huawei/pushkit/impl/PushKitSender.scala        |  9 +++
 .../huawei/pushkit/javadsl/HmsPushKit.scala        |  9 +++
 .../huawei/pushkit/models/AndroidConfig.scala      |  9 +++
 .../alpakka/huawei/pushkit/models/ApnsConfig.scala |  9 +++
 .../huawei/pushkit/models/BasicNotification.scala  |  9 +++
 .../huawei/pushkit/models/NotificationTarget.scala |  9 +++
 .../pushkit/models/PushKitNotification.scala       |  9 +++
 .../alpakka/huawei/pushkit/models/Response.scala   |  9 +++
 .../alpakka/huawei/pushkit/models/WebConfig.scala  |  9 +++
 .../huawei/pushkit/scaladsl/HmsPushKit.scala       |  9 +++
 .../alpakka/influxdb/InfluxDbReadSettings.scala    |  9 +++
 .../alpakka/influxdb/InfluxDbWriteMessage.scala    |  9 +++
 .../influxdb/impl/AlpakkaResultMapperHelper.scala  |  9 +++
 .../alpakka/influxdb/impl/InfluxDbFlowStage.scala  |  9 +++
 .../influxdb/impl/InfluxDbSourceStage.scala        |  9 +++
 .../alpakka/influxdb/javadsl/InfluxDbFlow.scala    |  9 +++
 .../alpakka/influxdb/javadsl/InfluxDbSink.scala    |  9 +++
 .../alpakka/influxdb/javadsl/InfluxDbSource.scala  |  9 +++
 .../alpakka/influxdb/scaladsl/InfluxDbFlow.scala   |  9 +++
 .../alpakka/influxdb/scaladsl/InfluxDbSink.scala   |  9 +++
 .../alpakka/influxdb/scaladsl/InfluxDbSource.scala |  9 +++
 .../stream/alpakka/ironmq/IronMqSettings.scala     |  9 +++
 .../scala/akka/stream/alpakka/ironmq/domain.scala  |  9 +++
 .../akka/stream/alpakka/ironmq/impl/Codec.scala    |  9 +++
 .../stream/alpakka/ironmq/impl/IronMqClient.scala  |  9 +++
 .../alpakka/ironmq/impl/IronMqPullStage.scala      |  9 +++
 .../alpakka/ironmq/impl/IronMqPushStage.scala      |  9 +++
 .../alpakka/ironmq/impl/ReservedMessage.scala      |  9 +++
 .../ironmq/javadsl/CommittableMessage.scala        |  9 +++
 .../alpakka/ironmq/javadsl/IronMqConsumer.scala    |  9 +++
 .../alpakka/ironmq/javadsl/IronMqProducer.scala    |  9 +++
 .../stream/alpakka/ironmq/javadsl/package.scala    |  9 +++
 .../ironmq/scaladsl/CommittableMessage.scala       |  9 +++
 .../alpakka/ironmq/scaladsl/IronMqConsumer.scala   |  9 +++
 .../alpakka/ironmq/scaladsl/IronMqProducer.scala   |  9 +++
 .../akka/stream/alpakka/jms/AcknowledgeMode.scala  |  9 +++
 .../alpakka/jms/ConnectionRetrySettings.scala      |  9 +++
 .../akka/stream/alpakka/jms/Credentials.scala      |  9 +++
 .../akka/stream/alpakka/jms/Destinations.scala     |  9 +++
 .../scala/akka/stream/alpakka/jms/Envelopes.scala  |  9 +++
 .../scala/akka/stream/alpakka/jms/Headers.scala    |  9 +++
 .../stream/alpakka/jms/JmsBrowseSettings.scala     |  9 +++
 .../stream/alpakka/jms/JmsConsumerSettings.scala   |  9 +++
 .../akka/stream/alpakka/jms/JmsExceptions.scala    |  9 +++
 .../akka/stream/alpakka/jms/JmsMessages.scala      |  9 +++
 .../stream/alpakka/jms/JmsProducerSettings.scala   |  9 +++
 .../akka/stream/alpakka/jms/JmsSettings.scala      |  9 +++
 .../stream/alpakka/jms/SendRetrySettings.scala     |  9 +++
 .../alpakka/jms/impl/InternalConnectionState.scala |  9 +++
 .../alpakka/jms/impl/JmsAckSourceStage.scala       |  9 +++
 .../stream/alpakka/jms/impl/JmsBrowseStage.scala   |  9 +++
 .../stream/alpakka/jms/impl/JmsConnector.scala     |  9 +++
 .../stream/alpakka/jms/impl/JmsConsumerStage.scala |  9 +++
 .../alpakka/jms/impl/JmsInternalMatValues.scala    |  9 +++
 .../alpakka/jms/impl/JmsMessageProducer.scala      |  9 +++
 .../stream/alpakka/jms/impl/JmsMessageReader.scala |  9 +++
 .../stream/alpakka/jms/impl/JmsProducerStage.scala |  9 +++
 .../stream/alpakka/jms/impl/JmsTxSourceStage.scala |  9 +++
 .../akka/stream/alpakka/jms/impl/Sessions.scala    |  9 +++
 .../alpakka/jms/impl/SoftReferenceCache.scala      |  9 +++
 .../stream/alpakka/jms/impl/SourceStageLogic.scala |  9 +++
 .../alpakka/jms/javadsl/JmsConnectorState.java     |  9 +++
 .../stream/alpakka/jms/javadsl/JmsConsumer.scala   |  9 +++
 .../alpakka/jms/javadsl/JmsConsumerControl.java    |  9 +++
 .../stream/alpakka/jms/javadsl/JmsProducer.scala   |  9 +++
 .../alpakka/jms/javadsl/JmsProducerStatus.java     |  9 +++
 .../alpakka/jms/scaladsl/JmsConnectorState.scala   |  9 +++
 .../stream/alpakka/jms/scaladsl/JmsConsumer.scala  |  9 +++
 .../stream/alpakka/jms/scaladsl/JmsProducer.scala  |  9 +++
 .../akka/stream/alpakka/jms/scaladsl/package.scala |  9 +++
 .../alpakka/json/impl/JsonStreamReader.scala       |  9 +++
 .../stream/alpakka/json/javadsl/JsonReader.scala   |  9 +++
 .../stream/alpakka/json/scaladsl/JsonReader.scala  |  9 +++
 .../stream/alpakka/kinesis/CommittableRecord.scala |  9 +++
 .../stream/alpakka/kinesis/KinesisErrors.scala     |  9 +++
 .../alpakka/kinesis/KinesisFlowSettings.scala      |  9 +++
 .../alpakka/kinesis/KinesisSchedulerErrors.scala   |  9 +++
 .../alpakka/kinesis/KinesisSchedulerSettings.scala |  9 +++
 .../stream/alpakka/kinesis/ShardIterator.scala     |  9 +++
 .../stream/alpakka/kinesis/ShardSettings.scala     |  9 +++
 .../kinesis/impl/KinesisSchedulerSourceStage.scala |  9 +++
 .../alpakka/kinesis/impl/KinesisSourceStage.scala  |  9 +++
 .../alpakka/kinesis/impl/ShardProcessor.scala      |  9 +++
 .../alpakka/kinesis/javadsl/KinesisFlow.scala      |  9 +++
 .../kinesis/javadsl/KinesisSchedulerSource.scala   |  9 +++
 .../alpakka/kinesis/javadsl/KinesisSink.scala      |  9 +++
 .../alpakka/kinesis/javadsl/KinesisSource.scala    |  9 +++
 .../alpakka/kinesis/scaladsl/KinesisFlow.scala     |  9 +++
 .../kinesis/scaladsl/KinesisSchedulerSource.scala  |  9 +++
 .../alpakka/kinesis/scaladsl/KinesisSink.scala     |  9 +++
 .../alpakka/kinesis/scaladsl/KinesisSource.scala   |  9 +++
 .../kinesisfirehose/KinesisFirehoseErrors.scala    |  9 +++
 .../KinesisFirehoseFlowSettings.scala              |  9 +++
 .../javadsl/KinesisFirehoseFlow.scala              |  9 +++
 .../javadsl/KinesisFirehoseSink.scala              |  9 +++
 .../scaladsl/KinesisFirehoseFlow.scala             |  9 +++
 .../scaladsl/KinesisFirehoseSink.scala             |  9 +++
 .../akka/stream/alpakka/kudu/KuduAttributes.scala  |  9 +++
 .../akka/stream/alpakka/kudu/KuduClientExt.scala   |  9 +++
 .../stream/alpakka/kudu/KuduTableSettings.scala    |  9 +++
 .../alpakka/kudu/impl/KuduCapabilities.scala       |  9 +++
 .../stream/alpakka/kudu/impl/KuduFlowStage.scala   |  9 +++
 .../stream/alpakka/kudu/javadsl/KuduTable.scala    |  9 +++
 .../stream/alpakka/kudu/scaladsl/KuduTable.scala   |  9 +++
 .../stream/alpakka/mongodb/DocumentReplace.scala   |  9 +++
 .../stream/alpakka/mongodb/DocumentUpdate.scala    |  9 +++
 .../stream/alpakka/mongodb/javadsl/MongoFlow.scala |  9 +++
 .../stream/alpakka/mongodb/javadsl/MongoSink.scala |  9 +++
 .../alpakka/mongodb/javadsl/MongoSource.scala      |  9 +++
 .../alpakka/mongodb/scaladsl/MongoFlow.scala       |  9 +++
 .../alpakka/mongodb/scaladsl/MongoSink.scala       |  9 +++
 .../alpakka/mongodb/scaladsl/MongoSource.scala     |  9 +++
 .../mqtt/streaming/MqttSessionSettings.scala       |  9 +++
 .../alpakka/mqtt/streaming/impl/ActorName.scala    |  9 +++
 .../mqtt/streaming/impl/BehaviorRunner.scala       |  9 +++
 .../alpakka/mqtt/streaming/impl/ClientState.scala  |  9 +++
 .../mqtt/streaming/impl/MqttFrameStage.scala       |  9 +++
 .../mqtt/streaming/impl/QueueOfferState.scala      |  9 +++
 .../alpakka/mqtt/streaming/impl/RequestState.scala |  9 +++
 .../alpakka/mqtt/streaming/impl/ServerState.scala  |  9 +++
 .../alpakka/mqtt/streaming/javadsl/Mqtt.scala      |  9 +++
 .../mqtt/streaming/javadsl/MqttSession.scala       |  9 +++
 .../akka/stream/alpakka/mqtt/streaming/model.scala |  9 +++
 .../alpakka/mqtt/streaming/scaladsl/Mqtt.scala     |  9 +++
 .../mqtt/streaming/scaladsl/MqttSession.scala      |  9 +++
 .../stream/alpakka/mqtt/impl/MqttFlowStage.scala   |  9 +++
 .../alpakka/mqtt/impl/MqttFlowStageWithAck.scala   |  9 +++
 .../stream/alpakka/mqtt/javadsl/MqttFlow.scala     |  9 +++
 .../alpakka/mqtt/javadsl/MqttMessageWithAck.scala  |  9 +++
 .../stream/alpakka/mqtt/javadsl/MqttSink.scala     |  9 +++
 .../stream/alpakka/mqtt/javadsl/MqttSource.scala   |  9 +++
 .../scala/akka/stream/alpakka/mqtt/model.scala     |  9 +++
 .../stream/alpakka/mqtt/scaladsl/MqttFlow.scala    |  9 +++
 .../alpakka/mqtt/scaladsl/MqttMessageWithAck.scala |  9 +++
 .../stream/alpakka/mqtt/scaladsl/MqttSink.scala    |  9 +++
 .../stream/alpakka/mqtt/scaladsl/MqttSource.scala  |  9 +++
 .../scala/akka/stream/alpakka/mqtt/settings.scala  |  9 +++
 .../alpakka/orientdb/OrientDbSourceSettings.scala  |  9 +++
 .../alpakka/orientdb/OrientDbWriteSettings.scala   |  9 +++
 .../alpakka/orientdb/impl/OrientDbFlowStage.scala  |  9 +++
 .../orientdb/impl/OrientDbSourceStage.scala        |  9 +++
 .../alpakka/orientdb/javadsl/OrientDbFlow.scala    |  9 +++
 .../alpakka/orientdb/javadsl/OrientDbSink.scala    |  9 +++
 .../alpakka/orientdb/javadsl/OrientDbSource.scala  |  9 +++
 .../scala/akka/stream/alpakka/orientdb/model.scala |  9 +++
 .../alpakka/orientdb/scaladsl/OrientDbFlow.scala   |  9 +++
 .../alpakka/orientdb/scaladsl/OrientDbSink.scala   |  9 +++
 .../alpakka/orientdb/scaladsl/OrientDbSource.scala |  9 +++
 .../stream/alpakka/pravega/javadsl/Pravega.java    |  9 +++
 .../alpakka/pravega/javadsl/PravegaTable.java      |  9 +++
 .../akka/stream/alpakka/pravega/PravegaEvent.scala |  9 +++
 .../pravega/PravegaReaderGroupManager.scala        |  9 +++
 .../stream/alpakka/pravega/PravegaSettings.scala   |  9 +++
 .../akka/stream/alpakka/pravega/TableEntry.scala   |  9 +++
 .../alpakka/pravega/impl/PravegaCapabilities.scala |  9 +++
 .../stream/alpakka/pravega/impl/PravegaFlow.scala  |  9 +++
 .../alpakka/pravega/impl/PravegaSource.scala       |  9 +++
 .../pravega/impl/PravegaTableReadFlow.scala        | 11 ++-
 .../alpakka/pravega/impl/PravegaTableSource.scala  |  9 +++
 .../pravega/impl/PravegaTableWriteFlow.scala       |  9 +++
 .../alpakka/pravega/impl/PravegaWriter.scala       |  9 +++
 .../stream/alpakka/pravega/scaladsl/Pravega.scala  |  9 +++
 .../alpakka/pravega/scaladsl/PravegaTable.scala    |  9 +++
 project/Common.scala                               |  2 -
 project/CopyrightHeader.scala                      | 90 ++++++++++++++++++++++
 project/CopyrightHeaderForBuild.scala              | 30 ++++++++
 .../akka/stream/alpakka/reference/Resource.scala   |  9 +++
 .../akka/stream/alpakka/reference/attributes.scala |  9 +++
 .../reference/impl/ReferenceFlowStage.scala        |  9 +++
 .../reference/impl/ReferenceSourceStage.scala      |  9 +++
 .../impl/ReferenceWithResourceFlowStage.scala      |  9 +++
 .../alpakka/reference/javadsl/Reference.scala      |  9 +++
 .../akka/stream/alpakka/reference/model.scala      |  9 +++
 .../alpakka/reference/scaladsl/Reference.scala     |  9 +++
 .../akka/stream/alpakka/reference/settings.scala   |  9 +++
 .../alpakka/reference/testkit/MessageFactory.scala |  9 +++
 .../akka/stream/alpakka/s3/S3Attributes.scala      |  9 +++
 .../scala/akka/stream/alpakka/s3/S3Exception.scala |  9 +++
 .../main/scala/akka/stream/alpakka/s3/S3Ext.scala  |  9 +++
 .../scala/akka/stream/alpakka/s3/S3Headers.scala   |  9 +++
 .../main/scala/akka/stream/alpakka/s3/Utils.scala  |  9 +++
 .../akka/stream/alpakka/s3/headers/CannedAcl.scala |  9 +++
 .../alpakka/s3/headers/ServerSideEncryption.scala  |  9 +++
 .../stream/alpakka/s3/headers/StorageClass.scala   |  9 +++
 .../scala/akka/stream/alpakka/s3/impl/Chunk.scala  |  9 +++
 .../akka/stream/alpakka/s3/impl/DiskBuffer.scala   |  9 +++
 .../akka/stream/alpakka/s3/impl/HttpRequests.scala |  9 +++
 .../akka/stream/alpakka/s3/impl/Marshalling.scala  |  9 +++
 .../akka/stream/alpakka/s3/impl/MemoryBuffer.scala |  9 +++
 .../stream/alpakka/s3/impl/MemoryWithContext.scala |  9 +++
 .../akka/stream/alpakka/s3/impl/S3Request.scala    |  9 +++
 .../akka/stream/alpakka/s3/impl/S3Stream.scala     | 17 +++-
 .../stream/alpakka/s3/impl/SplitAfterSize.scala    |  9 +++
 .../s3/impl/SplitAfterSizeWithContext.scala        |  9 +++
 .../alpakka/s3/impl/auth/CanonicalRequest.scala    |  9 +++
 .../akka/stream/alpakka/s3/impl/auth/Signer.scala  |  9 +++
 .../stream/alpakka/s3/impl/auth/SigningKey.scala   |  9 +++
 .../akka/stream/alpakka/s3/impl/auth/package.scala |  9 +++
 .../scala/akka/stream/alpakka/s3/javadsl/S3.scala  |  9 +++
 .../main/scala/akka/stream/alpakka/s3/model.scala  |  9 +++
 .../scala/akka/stream/alpakka/s3/scaladsl/S3.scala |  9 +++
 .../scala/akka/stream/alpakka/s3/settings.scala    |  9 +++
 .../recordio/impl/RecordIOFramingStage.scala       |  9 +++
 .../alpakka/recordio/javadsl/RecordIOFraming.scala |  9 +++
 .../recordio/scaladsl/RecordIOFraming.scala        |  9 +++
 .../akka/stream/alpakka/slick/javadsl/Slick.scala  |  9 +++
 .../stream/alpakka/slick/javadsl/package.scala     |  9 +++
 .../akka/stream/alpakka/slick/scaladsl/Slick.scala |  9 +++
 .../stream/alpakka/slick/scaladsl/package.scala    |  9 +++
 .../stream/alpakka/sns/SnsPublishSettings.scala    |  9 +++
 .../stream/alpakka/sns/javadsl/SnsPublisher.scala  |  9 +++
 .../stream/alpakka/sns/scaladsl/SnsPublisher.scala |  9 +++
 .../akka/stream/alpakka/solr/SolrMessages.scala    |  9 +++
 .../stream/alpakka/solr/SolrUpdateSettings.scala   |  9 +++
 .../stream/alpakka/solr/impl/SolrFlowStage.scala   |  9 +++
 .../stream/alpakka/solr/impl/SolrSourceStage.scala |  9 +++
 .../stream/alpakka/solr/javadsl/SolrFlow.scala     |  9 +++
 .../stream/alpakka/solr/javadsl/SolrSink.scala     |  9 +++
 .../stream/alpakka/solr/javadsl/SolrSource.scala   |  9 +++
 .../stream/alpakka/solr/scaladsl/SolrFlow.scala    |  9 +++
 .../stream/alpakka/solr/scaladsl/SolrSink.scala    |  9 +++
 .../stream/alpakka/solr/scaladsl/SolrSource.scala  |  9 +++
 .../alpakka/spring/web/AkkaStreamsRegistrar.java   |  9 +++
 .../web/SpringWebAkkaStreamsConfiguration.java     |  9 +++
 .../spring/web/SpringWebAkkaStreamsProperties.java |  9 +++
 .../stream/alpakka/sqs/SqsAckBatchSettings.scala   |  9 +++
 .../stream/alpakka/sqs/SqsAckGroupedSettings.scala |  9 +++
 .../akka/stream/alpakka/sqs/SqsAckSettings.scala   |  9 +++
 .../stream/alpakka/sqs/SqsBatchException.scala     |  9 +++
 .../scala/akka/stream/alpakka/sqs/SqsModel.scala   |  9 +++
 .../alpakka/sqs/SqsPublishBatchSettings.scala      |  9 +++
 .../alpakka/sqs/SqsPublishGroupedSettings.scala    |  9 +++
 .../stream/alpakka/sqs/SqsPublishSettings.scala    |  9 +++
 .../stream/alpakka/sqs/SqsSourceSettings.scala     |  9 +++
 .../alpakka/sqs/impl/BalancingMapAsync.scala       |  9 +++
 .../stream/alpakka/sqs/javadsl/SqsAckFlow.scala    |  9 +++
 .../stream/alpakka/sqs/javadsl/SqsAckSink.scala    |  9 +++
 .../alpakka/sqs/javadsl/SqsPublishFlow.scala       |  9 +++
 .../alpakka/sqs/javadsl/SqsPublishSink.scala       |  9 +++
 .../stream/alpakka/sqs/javadsl/SqsSource.scala     |  9 +++
 .../stream/alpakka/sqs/scaladsl/SqsAckFlow.scala   |  9 +++
 .../stream/alpakka/sqs/scaladsl/SqsAckSink.scala   |  9 +++
 .../alpakka/sqs/scaladsl/SqsPublishFlow.scala      |  9 +++
 .../alpakka/sqs/scaladsl/SqsPublishSink.scala      |  9 +++
 .../stream/alpakka/sqs/scaladsl/SqsSource.scala    |  9 +++
 .../alpakka/sqs/testkit/MessageFactory.scala       |  9 +++
 .../stream/alpakka/sse/javadsl/EventSource.scala   |  9 +++
 .../stream/alpakka/sse/scaladsl/EventSource.scala  |  9 +++
 .../alpakka/text/impl/CharsetDecodingFlow.scala    |  9 +++
 .../stream/alpakka/text/impl/CharsetLogic.scala    |  9 +++
 .../alpakka/text/impl/CharsetTranscodingFlow.scala |  9 +++
 .../stream/alpakka/text/javadsl/TextFlow.scala     |  9 +++
 .../stream/alpakka/text/scaladsl/TextFlow.scala    |  9 +++
 .../akka/stream/alpakka/udp/impl/UdpBind.scala     |  9 +++
 .../akka/stream/alpakka/udp/impl/UdpSend.scala     |  9 +++
 .../akka/stream/alpakka/udp/javadsl/Udp.scala      |  9 +++
 .../main/scala/akka/stream/alpakka/udp/model.scala |  9 +++
 .../akka/stream/alpakka/udp/scaladsl/Udp.scala     |  9 +++
 .../unixdomainsocket/UnixSocketAddress.scala       |  9 +++
 .../impl/UnixDomainSocketImpl.scala                |  9 +++
 .../javadsl/UnixDomainSocket.scala                 |  9 +++
 .../scaladsl/UnixDomainSocket.scala                |  9 +++
 .../akka/stream/alpakka/xml/ParseEventMarker.java  |  9 +++
 .../akka/stream/alpakka/xml/impl/Coalesce.scala    |  9 +++
 .../alpakka/xml/impl/StreamingXmlParser.scala      |  9 +++
 .../alpakka/xml/impl/StreamingXmlWriter.scala      |  9 +++
 .../akka/stream/alpakka/xml/impl/Subslice.scala    |  9 +++
 .../akka/stream/alpakka/xml/impl/Subtree.scala     |  9 +++
 .../stream/alpakka/xml/javadsl/XmlParsing.scala    |  9 +++
 .../stream/alpakka/xml/javadsl/XmlWriting.scala    |  9 +++
 .../main/scala/akka/stream/alpakka/xml/model.scala |  9 +++
 .../stream/alpakka/xml/scaladsl/XmlParsing.scala   |  9 +++
 .../stream/alpakka/xml/scaladsl/XmlWriting.scala   |  9 +++
 625 files changed, 5725 insertions(+), 9 deletions(-)

diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectionProvider.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectionProvider.scala
index 33fa6cd1..ca04c383 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectionProvider.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectionProvider.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectorSettings.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectorSettings.scala
index f608d5a1..b822a897 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectorSettings.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/AmqpConnectorSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpAsyncFlowStageLogic.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpAsyncFlowStageLogic.scala
index 87e2894b..e7ea176e 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpAsyncFlowStageLogic.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpAsyncFlowStageLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpFlowStageLogic.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpFlowStageLogic.scala
index cb15d008..bdc68f85 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpFlowStageLogic.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AbstractAmqpFlowStageLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncFlowStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncFlowStage.scala
index 6f91a0a5..16be46ea 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncFlowStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncUnorderedFlowStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncUnorderedFlowStage.scala
index d718871e..edaff84e 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncUnorderedFlowStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpAsyncUnorderedFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpConnectorLogic.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpConnectorLogic.scala
index 5729ead7..2ece8c33 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpConnectorLogic.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpConnectorLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpReplyToSinkStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpReplyToSinkStage.scala
index 52f0fa3f..fe934f9d 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpReplyToSinkStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpReplyToSinkStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpRpcFlowStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpRpcFlowStage.scala
index c46e4a61..c88eafd9 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpRpcFlowStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpRpcFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSimpleFlowStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSimpleFlowStage.scala
index 149e0808..0d7d59c4 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSimpleFlowStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSimpleFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSourceStage.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSourceStage.scala
index ab7c4754..4fa03c35 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSourceStage.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/impl/AmqpSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlow.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlow.scala
index 8c61ede6..d5e26d47 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlow.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlowWithContext.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlowWithContext.scala
index 53535496..b1757b9f 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlowWithContext.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpFlowWithContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpRpcFlow.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpRpcFlow.scala
index 9f28e57d..9975bdf5 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpRpcFlow.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpRpcFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSink.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSink.scala
index 52db94f8..9c850d3d 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSink.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSource.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSource.scala
index ec7d15a1..877b4289 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSource.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/AmqpSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/CommittableReadResult.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/CommittableReadResult.scala
index eab01703..eb3b8041 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/CommittableReadResult.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/javadsl/CommittableReadResult.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/model.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/model.scala
index b66e6f36..1c20c695 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/model.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlow.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlow.scala
index 6fb7235a..cbe522be 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlow.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlowWithContext.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlowWithContext.scala
index 358845c5..c5fa46de 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlowWithContext.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpFlowWithContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpRpcFlow.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpRpcFlow.scala
index cb711f12..b8024289 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpRpcFlow.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpRpcFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSink.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSink.scala
index 5f874325..c167d238 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSink.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSource.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSource.scala
index 967ecc86..42ebce14 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSource.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/AmqpSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/CommittableReadResult.scala b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/CommittableReadResult.scala
index b164422e..ee470a2e 100644
--- a/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/CommittableReadResult.scala
+++ b/amqp/src/main/scala/akka/stream/alpakka/amqp/scaladsl/CommittableReadResult.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetFlow.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetFlow.scala
index 901eaa2f..56d853fd 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetFlow.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetSource.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetSource.scala
index 331a13c0..6476a2c0 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetSource.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/impl/AvroParquetSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetFlow.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetFlow.scala
index 3813adb4..dd913da2 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetFlow.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSink.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSink.scala
index 8c594fd1..9fcbf057 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSink.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSource.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSource.scala
index 5b06118f..408167ce 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSource.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/javadsl/AvroParquetSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetFlow.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetFlow.scala
index 67845d9a..df34ce2e 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetFlow.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSink.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSink.scala
index c7fde124..851f7f07 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSink.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSource.scala b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSource.scala
index 5d376e46..f6f7cdad 100644
--- a/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSource.scala
+++ b/avroparquet/src/main/scala/akka/stream/alpakka/avroparquet/scaladsl/AvroParquetSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/EventBridgePublishSettings.scala b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/EventBridgePublishSettings.scala
index eee63cb6..4715b78a 100644
--- a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/EventBridgePublishSettings.scala
+++ b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/EventBridgePublishSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/javadsl/EventBridgePublisher.scala b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/javadsl/EventBridgePublisher.scala
index 8e360536..3de9958e 100644
--- a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/javadsl/EventBridgePublisher.scala
+++ b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/javadsl/EventBridgePublisher.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/scaladsl/EventBridgePublisher.scala b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/scaladsl/EventBridgePublisher.scala
index c31e27d3..23d5e1cb 100644
--- a/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/scaladsl/EventBridgePublisher.scala
+++ b/aws-event-bridge/src/main/scala/akka/stream/alpakka/aws/eventbridge/scaladsl/EventBridgePublisher.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/awslambda/src/main/scala/akka/stream/alpakka/awslambda/javadsl/AwsLambdaFlow.scala b/awslambda/src/main/scala/akka/stream/alpakka/awslambda/javadsl/AwsLambdaFlow.scala
index 10805e0c..088afe87 100644
--- a/awslambda/src/main/scala/akka/stream/alpakka/awslambda/javadsl/AwsLambdaFlow.scala
+++ b/awslambda/src/main/scala/akka/stream/alpakka/awslambda/javadsl/AwsLambdaFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/awslambda/src/main/scala/akka/stream/alpakka/awslambda/scaladsl/AwsLambdaFlow.scala b/awslambda/src/main/scala/akka/stream/alpakka/awslambda/scaladsl/AwsLambdaFlow.scala
index 30d3c63d..2bf93afd 100644
--- a/awslambda/src/main/scala/akka/stream/alpakka/awslambda/scaladsl/AwsLambdaFlow.scala
+++ b/awslambda/src/main/scala/akka/stream/alpakka/awslambda/scaladsl/AwsLambdaFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSinkFunctions.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSinkFunctions.scala
index 3ccaca3d..746650ae 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSinkFunctions.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSinkFunctions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSourceStage.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSourceStage.scala
index c22c1495..c1cf17aa 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSourceStage.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/impl/AzureQueueSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSink.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSink.scala
index 63ff38f2..63e528cd 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSink.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSource.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSource.scala
index 56d530e4..0957ec45 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSource.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/javadsl/AzureQueueSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/model.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/model.scala
index 7d8690c2..2a5e0721 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/model.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSink.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSink.scala
index fb73743b..a4943f50 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSink.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSource.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSource.scala
index 54756788..46085c0b 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSource.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/scaladsl/AzureQueueSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/settings.scala b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/settings.scala
index 495a98a8..d3d08d93 100644
--- a/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/settings.scala
+++ b/azure-storage-queue/src/main/scala/akka/stream/alpakka/azure/storagequeue/settings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/AkkaDiscoverySessionProvider.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/AkkaDiscoverySessionProvider.scala
index dac15aee..de389948 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/AkkaDiscoverySessionProvider.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/AkkaDiscoverySessionProvider.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraMetricsRegistry.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraMetricsRegistry.scala
index 5fa716a6..41dbc540 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraMetricsRegistry.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraMetricsRegistry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraServerMetaData.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraServerMetaData.scala
index 1dd6830b..a12e7d11 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraServerMetaData.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraServerMetaData.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraSessionSettings.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraSessionSettings.scala
index f71f1089..2e78ad02 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraSessionSettings.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraSessionSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraWriteSettings.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraWriteSettings.scala
index 29e6d0f1..8c1e991c 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraWriteSettings.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CassandraWriteSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CqlSessionProvider.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CqlSessionProvider.scala
index b7ff21ae..cab952bc 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CqlSessionProvider.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/CqlSessionProvider.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/DriverConfigLoaderFromConfig.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/DriverConfigLoaderFromConfig.scala
index 8afee6e3..ac649dbe 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/DriverConfigLoaderFromConfig.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/DriverConfigLoaderFromConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraFlow.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraFlow.scala
index f41e7c79..9bb56ef1 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraFlow.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSession.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSession.scala
index 241d760d..e5a0ed22 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSession.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSessionRegistry.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSessionRegistry.scala
index 34eba615..9390e8e2 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSessionRegistry.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSessionRegistry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSource.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSource.scala
index 33caceda..19bbe7e3 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSource.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/javadsl/CassandraSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraFlow.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraFlow.scala
index 20747ab2..48d591c0 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraFlow.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSession.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSession.scala
index d05219e8..6198b619 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSession.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSessionRegistry.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSessionRegistry.scala
index 820cd81a..76b1fb36 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSessionRegistry.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSessionRegistry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSource.scala b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSource.scala
index a0d3148b..c9d5ed41 100644
--- a/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSource.scala
+++ b/cassandra/src/main/scala/akka/stream/alpakka/cassandra/scaladsl/CassandraSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/java/akka/stream/alpakka/couchbase/javadsl/DiscoverySupport.java b/couchbase/src/main/java/akka/stream/alpakka/couchbase/javadsl/DiscoverySupport.java
index a86630ca..a788d08e 100644
--- a/couchbase/src/main/java/akka/stream/alpakka/couchbase/javadsl/DiscoverySupport.java
+++ b/couchbase/src/main/java/akka/stream/alpakka/couchbase/javadsl/DiscoverySupport.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseResponseException.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseResponseException.scala
index 1ff29f69..1af66a97 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseResponseException.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseResponseException.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseSessionRegistry.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseSessionRegistry.scala
index b806f5ea..b9dbdf35 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseSessionRegistry.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/CouchbaseSessionRegistry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseClusterRegistry.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseClusterRegistry.scala
index 7adbc43a..a30321d9 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseClusterRegistry.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseClusterRegistry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionImpl.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionImpl.scala
index cd3667d7..79379978 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionImpl.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionJavaAdapter.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionJavaAdapter.scala
index 43eb25a6..596a17c3 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionJavaAdapter.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/CouchbaseSessionJavaAdapter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/RxUtilities.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/RxUtilities.scala
index b2858bf2..a2862e6e 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/RxUtilities.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/impl/RxUtilities.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseFlow.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseFlow.scala
index efbfbe81..a6987cdb 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseFlow.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSession.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSession.scala
index 9a1e2f23..cd69bfa5 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSession.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSink.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSink.scala
index 593f6a01..e81b373e 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSink.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSource.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSource.scala
index 0750bdbf..218a8ea7 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSource.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/javadsl/CouchbaseSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/model.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/model.scala
index 6eb1d283..4da8f262 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/model.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseFlow.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseFlow.scala
index e872713a..559cd2c9 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseFlow.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSession.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSession.scala
index 8700bd2a..b10f509b 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSession.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSink.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSink.scala
index 7d058951..8b7c30aa 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSink.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSource.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSource.scala
index 62aadca2..0d4e40c3 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSource.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/CouchbaseSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/DiscoverySupport.scala b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/DiscoverySupport.scala
index b026c8b8..0fd847cf 100644
--- a/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/DiscoverySupport.scala
+++ b/couchbase/src/main/scala/akka/stream/alpakka/couchbase/scaladsl/DiscoverySupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/ByteOrderMark.java b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/ByteOrderMark.java
index 6c7cefb3..efa41bf7 100644
--- a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/ByteOrderMark.java
+++ b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/ByteOrderMark.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvFormatting.java b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvFormatting.java
index fe8d99aa..c7942304 100644
--- a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvFormatting.java
+++ b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvFormatting.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvParsing.java b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvParsing.java
index 7c9089ad..78bd91cd 100644
--- a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvParsing.java
+++ b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvParsing.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvQuotingStyle.java b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvQuotingStyle.java
index ee4d1f14..8479d496 100644
--- a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvQuotingStyle.java
+++ b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvQuotingStyle.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvToMap.java b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvToMap.java
index d20d6799..fbd42e61 100644
--- a/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvToMap.java
+++ b/csv/src/main/java/akka/stream/alpakka/csv/javadsl/CsvToMap.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvFormatter.scala b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvFormatter.scala
index d8efe7a2..34326dd3 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvFormatter.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvFormatter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParser.scala b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParser.scala
index 13ca679b..a4934465 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParser.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParser.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParsingStage.scala b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParsingStage.scala
index f1c9f0a5..1def7565 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParsingStage.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvParsingStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapJavaStage.scala b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapJavaStage.scala
index 3240d234..7ee0dc0e 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapJavaStage.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapJavaStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapStage.scala b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapStage.scala
index 2366a1f0..d39c854a 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapStage.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/impl/CsvToMapStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/model.scala b/csv/src/main/scala/akka/stream/alpakka/csv/model.scala
index d4721694..c4c4a4c8 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/model.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/ByteOrderMark.scala b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/ByteOrderMark.scala
index 801b3f7d..e51b9498 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/ByteOrderMark.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/ByteOrderMark.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvFormatting.scala b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvFormatting.scala
index 6ab6b0c5..48c2efbe 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvFormatting.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvFormatting.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvParsing.scala b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvParsing.scala
index 27f5063a..1b581327 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvParsing.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvParsing.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvQuotingStyle.scala b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvQuotingStyle.scala
index f9d13ff5..cf5263aa 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvQuotingStyle.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvQuotingStyle.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvToMap.scala b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvToMap.scala
index b74d8aef..036d4809 100644
--- a/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvToMap.scala
+++ b/csv/src/main/scala/akka/stream/alpakka/csv/scaladsl/CsvToMap.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/DynamoDbOp.scala b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/DynamoDbOp.scala
index 81a5d1f5..f3e8b424 100644
--- a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/DynamoDbOp.scala
+++ b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/DynamoDbOp.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/javadsl/DynamoDb.scala b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/javadsl/DynamoDb.scala
index e5f0886a..f1d6e512 100644
--- a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/javadsl/DynamoDb.scala
+++ b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/javadsl/DynamoDb.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/scaladsl/DynamoDb.scala b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/scaladsl/DynamoDb.scala
index e7fe2036..e4364e66 100644
--- a/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/scaladsl/DynamoDb.scala
+++ b/dynamodb/src/main/scala/akka/stream/alpakka/dynamodb/scaladsl/DynamoDb.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersion.java b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersion.java
index 9064a8aa..c97447e3 100644
--- a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersion.java
+++ b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersion.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersionBase.java b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersionBase.java
index 13bd1d0d..ac812487 100644
--- a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersionBase.java
+++ b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/ApiVersionBase.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/OpensearchApiVersion.java b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/OpensearchApiVersion.java
index 4ea70425..bef76917 100644
--- a/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/OpensearchApiVersion.java
+++ b/elasticsearch/src/main/java/akka/stream/alpakka/elasticsearch/OpensearchApiVersion.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchConnectionSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchConnectionSettings.scala
index f1078e3e..d24be7c9 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchConnectionSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchConnectionSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchParams.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchParams.scala
index 70a91a66..d3bf3b5b 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchParams.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchParams.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchSourceSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchSourceSettings.scala
index e1394d81..826606ac 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchSourceSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchSourceSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchWriteSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchWriteSettings.scala
index b51da675..04aac527 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchWriteSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ElasticsearchWriteSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchConnectionSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchConnectionSettings.scala
index 90a4f429..4382ab5e 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchConnectionSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchConnectionSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchParams.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchParams.scala
index 2de330dd..18af9207 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchParams.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchParams.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchSourceSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchSourceSettings.scala
index 846c573f..c66cbf0e 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchSourceSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchSourceSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchWriteSettings.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchWriteSettings.scala
index cb17923a..663da8ba 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchWriteSettings.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/OpensearchWriteSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ReadResult.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ReadResult.scala
index 6ed80da6..d4c40489 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ReadResult.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/ReadResult.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/SourceSettingsBase.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/SourceSettingsBase.scala
index 1d67faa9..0f3f495c 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/SourceSettingsBase.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/SourceSettingsBase.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteMessage.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteMessage.scala
index 65ec975f..bf1287cd 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteMessage.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteSettingsBase.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteSettingsBase.scala
index 091d9c9a..c374de2f 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteSettingsBase.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/WriteSettingsBase.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchApi.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchApi.scala
index 9719fe57..75a2b14a 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchApi.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSimpleFlowStage.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSimpleFlowStage.scala
index 241d9319..4b277bc9 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSimpleFlowStage.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSimpleFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSourceStage.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSourceStage.scala
index d132b499..606ef2cb 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSourceStage.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/ElasticsearchSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/NDJsonProtocol.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/NDJsonProtocol.scala
index 6c5b4a32..652c9ba2 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/NDJsonProtocol.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/NDJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApi.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApi.scala
index b8262a85..68800ee2 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApi.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV5.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV5.scala
index f9c1c1fb..7a4e58f3 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV5.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV5.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV7.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV7.scala
index 45f5c45d..19faa705 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV7.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/impl/RestBulkApiV7.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchFlow.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchFlow.scala
index fa9759ce..2e1961a8 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchFlow.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSink.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSink.scala
index a0cfc461..b251fde5 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSink.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSource.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSource.scala
index abb1a76e..4962dcee 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSource.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/javadsl/ElasticsearchSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchFlow.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchFlow.scala
index fb7c9e42..0a5a097f 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchFlow.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
@@ -170,8 +179,8 @@ object ElasticsearchFlow {
   }
 
   @InternalApi
-  private def amendWithIndexFlow[T, C]: Flow[immutable.Seq[WriteMessage[T, C]],
-    (immutable.Seq[WriteMessage[T, (Int, C)]], immutable.Seq[WriteResult[T, (Int, C)]]), NotUsed] = {
+  private def amendWithIndexFlow[T, C]: Flow[immutable.Seq[WriteMessage[T, C]], (immutable.Seq[WriteMessage[T, (Int,
+              C)]], immutable.Seq[WriteResult[T, (Int, C)]]), NotUsed] = {
     Flow[immutable.Seq[WriteMessage[T, C]]].map { messages =>
       val indexedMessages = messages.zipWithIndex.map {
         case (m, idx) =>
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSink.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSink.scala
index 254d98b3..f9628996 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSink.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSource.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSource.scala
index 3029ea62..99d88af8 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSource.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/scaladsl/ElasticsearchSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/testkit/MessageFactory.scala b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/testkit/MessageFactory.scala
index be343236..8bac6fc3 100644
--- a/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/testkit/MessageFactory.scala
+++ b/elasticsearch/src/main/scala/akka/stream/alpakka/elasticsearch/testkit/MessageFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/DirectoryChange.java b/file/src/main/java/akka/stream/alpakka/file/DirectoryChange.java
index f8310ea3..537aab1e 100644
--- a/file/src/main/java/akka/stream/alpakka/file/DirectoryChange.java
+++ b/file/src/main/java/akka/stream/alpakka/file/DirectoryChange.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/impl/DirectoryChangesSource.java b/file/src/main/java/akka/stream/alpakka/file/impl/DirectoryChangesSource.java
index 653f3fea..c2b4a897 100644
--- a/file/src/main/java/akka/stream/alpakka/file/impl/DirectoryChangesSource.java
+++ b/file/src/main/java/akka/stream/alpakka/file/impl/DirectoryChangesSource.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/impl/FileTailSource.java b/file/src/main/java/akka/stream/alpakka/file/impl/FileTailSource.java
index 2b22be9e..533fb24a 100644
--- a/file/src/main/java/akka/stream/alpakka/file/impl/FileTailSource.java
+++ b/file/src/main/java/akka/stream/alpakka/file/impl/FileTailSource.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/javadsl/Directory.java b/file/src/main/java/akka/stream/alpakka/file/javadsl/Directory.java
index 06d50232..db645cd5 100644
--- a/file/src/main/java/akka/stream/alpakka/file/javadsl/Directory.java
+++ b/file/src/main/java/akka/stream/alpakka/file/javadsl/Directory.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/javadsl/DirectoryChangesSource.java b/file/src/main/java/akka/stream/alpakka/file/javadsl/DirectoryChangesSource.java
index dc0c0914..1e71dd5d 100644
--- a/file/src/main/java/akka/stream/alpakka/file/javadsl/DirectoryChangesSource.java
+++ b/file/src/main/java/akka/stream/alpakka/file/javadsl/DirectoryChangesSource.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/java/akka/stream/alpakka/file/javadsl/FileTailSource.java b/file/src/main/java/akka/stream/alpakka/file/javadsl/FileTailSource.java
index 0162730c..40a01073 100644
--- a/file/src/main/java/akka/stream/alpakka/file/javadsl/FileTailSource.java
+++ b/file/src/main/java/akka/stream/alpakka/file/javadsl/FileTailSource.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/EnsureByteStreamSize.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/EnsureByteStreamSize.scala
index e8234a88..dabb0351 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/EnsureByteStreamSize.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/EnsureByteStreamSize.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/FileByteStringSeparators.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/FileByteStringSeparators.scala
index ec9284eb..2678f0c0 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/FileByteStringSeparators.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/FileByteStringSeparators.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveEntry.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveEntry.scala
index cbc304e6..c79250e5 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveEntry.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveEntry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveManager.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveManager.scala
index a778e08e..c79ec1fe 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveManager.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarArchiveManager.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarReaderStage.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarReaderStage.scala
index 0a5e6928..e0028961 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarReaderStage.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/TarReaderStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveFlow.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveFlow.scala
index d1567cbf..7e405dfc 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveFlow.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveManager.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveManager.scala
index 97b12243..8e637231 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveManager.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipArchiveManager.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipReaderSource.scala b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipReaderSource.scala
index 52d441aa..07ca56f3 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipReaderSource.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/impl/archive/ZipReaderSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/javadsl/Archive.scala b/file/src/main/scala/akka/stream/alpakka/file/javadsl/Archive.scala
index e7d5fa6c..b8339224 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/javadsl/Archive.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/javadsl/Archive.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/javadsl/LogRotatorSink.scala b/file/src/main/scala/akka/stream/alpakka/file/javadsl/LogRotatorSink.scala
index 40528009..3fd79636 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/javadsl/LogRotatorSink.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/javadsl/LogRotatorSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/model.scala b/file/src/main/scala/akka/stream/alpakka/file/model.scala
index 641ec56e..bf88dd7c 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/model.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Archive.scala b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Archive.scala
index 90937cc9..e4e4af1a 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Archive.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Archive.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Directory.scala b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Directory.scala
index 970d058e..07a8c2b3 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Directory.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/Directory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/DirectoryChangesSource.scala b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/DirectoryChangesSource.scala
index a4f56edc..6d50064b 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/DirectoryChangesSource.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/DirectoryChangesSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/FileTailSource.scala b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/FileTailSource.scala
index f4def70d..d02cf116 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/FileTailSource.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/FileTailSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/LogRotatorSink.scala b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/LogRotatorSink.scala
index 7bd1615f..68c90528 100644
--- a/file/src/main/scala/akka/stream/alpakka/file/scaladsl/LogRotatorSink.scala
+++ b/file/src/main/scala/akka/stream/alpakka/file/scaladsl/LogRotatorSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/CommonFtpOperations.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/CommonFtpOperations.scala
index a1f8c96f..1e677afd 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/CommonFtpOperations.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/CommonFtpOperations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpBrowserGraphStage.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpBrowserGraphStage.scala
index e484fcbc..7d3379c1 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpBrowserGraphStage.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpBrowserGraphStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpDirectoryOperationsGraphStage.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpDirectoryOperationsGraphStage.scala
index c6b26712..f8d4c1ec 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpDirectoryOperationsGraphStage.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpDirectoryOperationsGraphStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStage.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStage.scala
index 7b05ad3a..a4f98bc8 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStage.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStageLogic.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStageLogic.scala
index 18010607..2a42f600 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStageLogic.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpGraphStageLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpIOGraphStage.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpIOGraphStage.scala
index 3aeafe6e..3d9f87c0 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpIOGraphStage.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpIOGraphStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpLike.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpLike.scala
index 3ff412b1..f6eaed17 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpLike.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpLike.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpOperations.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpOperations.scala
index 77d2d691..f551b695 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpOperations.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpOperations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpSourceFactory.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpSourceFactory.scala
index 7188e422..5ebd5225 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpSourceFactory.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpSourceFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpsOperations.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpsOperations.scala
index 75060364..ab7d76a3 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpsOperations.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/FtpsOperations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/SftpOperations.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/SftpOperations.scala
index 87e6f684..8cc35d2d 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/SftpOperations.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/impl/SftpOperations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/javadsl/FtpApi.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/javadsl/FtpApi.scala
index a2dc1109..23feaffa 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/javadsl/FtpApi.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/javadsl/FtpApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/model.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/model.scala
index c331e898..6e350515 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/model.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ftp/src/main/scala/akka/stream/alpakka/ftp/scaladsl/FtpApi.scala b/ftp/src/main/scala/akka/stream/alpakka/ftp/scaladsl/FtpApi.scala
index ff981911..c401eed6 100644
--- a/ftp/src/main/scala/akka/stream/alpakka/ftp/scaladsl/FtpApi.scala
+++ b/ftp/src/main/scala/akka/stream/alpakka/ftp/scaladsl/FtpApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/java/akka/stream/alpakka/geode/javadsl/Geode.java b/geode/src/main/java/akka/stream/alpakka/geode/javadsl/Geode.java
index fdb055b2..cea11b61 100644
--- a/geode/src/main/java/akka/stream/alpakka/geode/javadsl/Geode.java
+++ b/geode/src/main/java/akka/stream/alpakka/geode/javadsl/Geode.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/java/akka/stream/alpakka/geode/javadsl/GeodeWithPoolSubscription.java b/geode/src/main/java/akka/stream/alpakka/geode/javadsl/GeodeWithPoolSubscription.java
index b0564882..1efb0d86 100644
--- a/geode/src/main/java/akka/stream/alpakka/geode/javadsl/GeodeWithPoolSubscription.java
+++ b/geode/src/main/java/akka/stream/alpakka/geode/javadsl/GeodeWithPoolSubscription.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/AkkaPdxSerializer.scala b/geode/src/main/scala/akka/stream/alpakka/geode/AkkaPdxSerializer.scala
index b71b2012..45c0693e 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/AkkaPdxSerializer.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/AkkaPdxSerializer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/GeodeSettings.scala b/geode/src/main/scala/akka/stream/alpakka/geode/GeodeSettings.scala
index 49a18e94..29827597 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/GeodeSettings.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/GeodeSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCache.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCache.scala
index 6f36c27c..11f1a7d1 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCache.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCache.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCapabilities.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCapabilities.scala
index c872208e..3af70338 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCapabilities.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/GeodeCapabilities.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/DelegatingPdxSerializer.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/DelegatingPdxSerializer.scala
index b15510e5..af980149 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/DelegatingPdxSerializer.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/DelegatingPdxSerializer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxDecoder.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxDecoder.scala
index 5b235085..213dd03b 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxDecoder.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxDecoder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxEncoder.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxEncoder.scala
index b8cb223d..5ca48975 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxEncoder.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/PdxEncoder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/ShapelessPdxSerializer.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/ShapelessPdxSerializer.scala
index 04cc4425..5fedbc0c 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/ShapelessPdxSerializer.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/pdx/ShapelessPdxSerializer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeCQueryGraphLogic.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeCQueryGraphLogic.scala
index b76474da..e0175eae 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeCQueryGraphLogic.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeCQueryGraphLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeContinuousSourceStage.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeContinuousSourceStage.scala
index b479d214..e4e993af 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeContinuousSourceStage.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeContinuousSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFiniteSourceStage.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFiniteSourceStage.scala
index 325081fd..3b73a236 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFiniteSourceStage.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFiniteSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFlowStage.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFlowStage.scala
index 5a1a2a39..49c691c5 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFlowStage.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeQueryGraphLogic.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeQueryGraphLogic.scala
index 83d4d5c3..8069abd1 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeQueryGraphLogic.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeQueryGraphLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeSourceStageLogic.scala b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeSourceStageLogic.scala
index c4b7cee8..d65c3c62 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeSourceStageLogic.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/impl/stage/GeodeSourceStageLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/geode/src/main/scala/akka/stream/alpakka/geode/scaladsl/Geode.scala b/geode/src/main/scala/akka/stream/alpakka/geode/scaladsl/Geode.scala
index 687dee19..c11476f4 100644
--- a/geode/src/main/scala/akka/stream/alpakka/geode/scaladsl/Geode.scala
+++ b/geode/src/main/scala/akka/stream/alpakka/geode/scaladsl/Geode.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryRecordMapImpl.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryRecordMapImpl.scala
index 76276270..db2f0ed9 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryRecordMapImpl.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryRecordMapImpl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryStorageSettings.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryStorageSettings.scala
index d59a919d..bb6887a1 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryStorageSettings.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/BigQueryStorageSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/ProtobufConverters.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/ProtobufConverters.scala
index 45729360..ab895832 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/ProtobufConverters.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/ProtobufConverters.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AkkaGrpcSettings.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AkkaGrpcSettings.scala
index 78ec8236..f10115d9 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AkkaGrpcSettings.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AkkaGrpcSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/ArrowSource.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/ArrowSource.scala
index b1be66b2..a94d32e5 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/ArrowSource.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/ArrowSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroDecoder.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroDecoder.scala
index 885db67d..bc7dafa5 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroDecoder.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroDecoder.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroSource.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroSource.scala
index c6bdda10..fc283854 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroSource.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/AvroSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/SDKClientSource.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/SDKClientSource.scala
index 5d6282c4..617dc1c7 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/SDKClientSource.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/impl/SDKClientSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryArrowStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryArrowStorage.scala
index cea7f309..d9431f38 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryArrowStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryArrowStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryAvroStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryAvroStorage.scala
index e951538d..f3b7d29f 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryAvroStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryAvroStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryStorage.scala
index 1ed36cdc..c84a8a4a 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/javadsl/BigQueryStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryArrowStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryArrowStorage.scala
index d97c6cdd..16e18a41 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryArrowStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryArrowStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryAvroStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryAvroStorage.scala
index e013a552..8efe59d1 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryAvroStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryAvroStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorage.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorage.scala
index e59d19d8..ef6e0475 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorage.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorageAttributes.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorageAttributes.scala
index 0a6790ae..2da151ec 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorageAttributes.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/BigQueryStorageAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/GrpcBigQueryStorageReader.scala b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/GrpcBigQueryStorageReader.scala
index 8486c5fa..43b267a7 100644
--- a/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/GrpcBigQueryStorageReader.scala
+++ b/google-cloud-bigquery-storage/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/storage/scaladsl/GrpcBigQueryStorageReader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryAttributes.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryAttributes.scala
index d1041f64..3b118e9d 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryAttributes.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryEndpoints.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryEndpoints.scala
index 681d5f7a..73a54417 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryEndpoints.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryEndpoints.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryException.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryException.scala
index 49ed0f91..c865a103 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryException.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryException.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryExt.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryExt.scala
index ba686de0..80903122 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryExt.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQueryExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQuerySettings.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQuerySettings.scala
index e356c1f1..3baf54a1 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQuerySettings.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/BigQuerySettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/InsertAllRetryPolicy.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/InsertAllRetryPolicy.scala
index 82012983..0a6b79da 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/InsertAllRetryPolicy.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/InsertAllRetryPolicy.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/BigQuery.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/BigQuery.scala
index f3676e99..390d090f 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/BigQuery.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/BigQuery.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/jackson/BigQueryMarshallers.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/jackson/BigQueryMarshallers.scala
index f43dc9b8..f0e74b3d 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/jackson/BigQueryMarshallers.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/javadsl/jackson/BigQueryMarshallers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/DatasetJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/DatasetJsonProtocol.scala
index e831079b..66505f06 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/DatasetJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/DatasetJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/ErrorProtoJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/ErrorProtoJsonProtocol.scala
index 88ac8d12..74b8728e 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/ErrorProtoJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/ErrorProtoJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/JobJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/JobJsonProtocol.scala
index 0dd1ca02..559fd0e9 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/JobJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/JobJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/QueryJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/QueryJsonProtocol.scala
index 53a21560..308c55b1 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/QueryJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/QueryJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/StringEnum.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/StringEnum.scala
index 683c9bed..d8e6ba65 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/StringEnum.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/StringEnum.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableDataJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableDataJsonProtocol.scala
index dd9fbfe4..8d36a8cc 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableDataJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableDataJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableJsonProtocol.scala
index 4b829922..530ba49c 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/model/TableJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQuery.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQuery.scala
index 9e073d8a..100b86df 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQuery.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQuery.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryDatasets.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryDatasets.scala
index e7247c06..f3960958 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryDatasets.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryDatasets.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryJobs.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryJobs.scala
index bcb93b84..9b3a546c 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryJobs.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryJobs.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryQueries.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryQueries.scala
index 2ff4ffc1..bd0c14d0 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryQueries.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryQueries.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryRest.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryRest.scala
index 0c857c0f..d66668d0 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryRest.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryRest.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTableData.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTableData.scala
index 8830ee72..e47f0e3d 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTableData.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTableData.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTables.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTables.scala
index 85bb96f8..c1196dfd 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTables.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/BigQueryTables.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BasicSchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BasicSchemas.scala
index b3e0f32f..a5d7747f 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BasicSchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BasicSchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BigQuerySchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BigQuerySchemas.scala
index f634ed5b..ce872192 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BigQuerySchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/BigQuerySchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/CollectionSchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/CollectionSchemas.scala
index aeb3be20..39b53633 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/CollectionSchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/CollectionSchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/JavaTimeSchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/JavaTimeSchemas.scala
index d81bc6ad..370073d0 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/JavaTimeSchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/JavaTimeSchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/PrimitiveSchemaWriter.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/PrimitiveSchemaWriter.scala
index 7a7158c2..f39c9d00 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/PrimitiveSchemaWriter.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/PrimitiveSchemaWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/ProductSchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/ProductSchemas.scala
index 1b45a8a5..4086a68c 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/ProductSchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/ProductSchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/Schema.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/Schema.scala
index 754eb2e5..b0c5b338 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/Schema.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/Schema.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/SchemaWriter.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/SchemaWriter.scala
index 4c57d05f..ab9ee95e 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/SchemaWriter.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/SchemaWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/StandardSchemas.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/StandardSchemas.scala
index 365c14b5..dfc74505 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/StandardSchemas.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/schema/StandardSchemas.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBasicFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBasicFormats.scala
index dec7ef51..ca93bbba 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBasicFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBasicFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBytes.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBytes.scala
index bcf607ff..32e460dd 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBytes.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryBytes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryCollectionFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryCollectionFormats.scala
index db373e35..ef334471 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryCollectionFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryCollectionFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJavaTimeFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJavaTimeFormats.scala
index 73ad4a3b..84da9002 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJavaTimeFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJavaTimeFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonFormat.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonFormat.scala
index ce409958..b9ac3cb7 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonFormat.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonFormat.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonProtocol.scala
index d1ade2fe..ed291602 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryNumber.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryNumber.scala
index 7769841e..87ca136f 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryNumber.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryNumber.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryProductFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryProductFormats.scala
index 78ab1972..0083b9cb 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryProductFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryProductFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestBasicFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestBasicFormats.scala
index d0df1862..798c0938 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestBasicFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestBasicFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestJsonProtocol.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestJsonProtocol.scala
index 77f5cfb4..57b45b4d 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestJsonProtocol.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryRestJsonProtocol.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryStandardFormats.scala b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryStandardFormats.scala
index 17cdff46..50069d7c 100644
--- a/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryStandardFormats.scala
+++ b/google-cloud-bigquery/src/main/scala/akka/stream/alpakka/googlecloud/bigquery/scaladsl/spray/BigQueryStandardFormats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/PubSubSettings.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/PubSubSettings.scala
index 5609e5e8..e704fba7 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/PubSubSettings.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/PubSubSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/AkkaGrpcSettings.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/AkkaGrpcSettings.scala
index 046a3f85..ea860ca1 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/AkkaGrpcSettings.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/AkkaGrpcSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/DeprecatedCredentials.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/DeprecatedCredentials.scala
index 8b740eb2..b604518e 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/DeprecatedCredentials.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/impl/DeprecatedCredentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GooglePubSub.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GooglePubSub.scala
index ce73b16b..575085bb 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GooglePubSub.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GooglePubSub.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcPublisher.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcPublisher.scala
index a3bef6a6..c1957543 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcPublisher.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcPublisher.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcSubscriber.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcSubscriber.scala
index 9099e0e6..0696b51a 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcSubscriber.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/GrpcSubscriber.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/PubSubAttributes.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/PubSubAttributes.scala
index 29bf911e..3ab257b9 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/PubSubAttributes.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/javadsl/PubSubAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GooglePubSub.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GooglePubSub.scala
index c76d5f68..40b625f5 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GooglePubSub.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GooglePubSub.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcPublisher.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcPublisher.scala
index 3bcacca0..51057eee 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcPublisher.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcPublisher.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcSubscriber.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcSubscriber.scala
index d6b2cd38..a1d77034 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcSubscriber.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/GrpcSubscriber.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/PubSubAttributes.scala b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/PubSubAttributes.scala
index 0d8692df..a9b76e1d 100644
--- a/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/PubSubAttributes.scala
+++ b/google-cloud-pub-sub-grpc/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/grpc/scaladsl/PubSubAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/impl/PubSubApi.scala b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/impl/PubSubApi.scala
index 08f1be68..bb11f5f1 100644
--- a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/impl/PubSubApi.scala
+++ b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/impl/PubSubApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/javadsl/GooglePubSub.scala b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/javadsl/GooglePubSub.scala
index f6bd04cd..dd796838 100644
--- a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/javadsl/GooglePubSub.scala
+++ b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/javadsl/GooglePubSub.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/model.scala b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/model.scala
index ca7e1aea..0bbb507a 100644
--- a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/model.scala
+++ b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/scaladsl/GooglePubSub.scala b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/scaladsl/GooglePubSub.scala
index da17b254..2c135d19 100644
--- a/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/scaladsl/GooglePubSub.scala
+++ b/google-cloud-pub-sub/src/main/scala/akka/stream/alpakka/googlecloud/pubsub/scaladsl/GooglePubSub.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Bucket.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Bucket.scala
index 1a96b9d6..703cc939 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Bucket.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Bucket.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/CustomerEncryption.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/CustomerEncryption.scala
index 89130745..1ddfe779 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/CustomerEncryption.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/CustomerEncryption.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/FailedUpload.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/FailedUpload.scala
index a7a66bb5..3ab9e5ca 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/FailedUpload.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/FailedUpload.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSAttributes.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSAttributes.scala
index 139dc5fc..95dd6752 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSAttributes.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSExt.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSExt.scala
index 6a2007f3..a3c680c5 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSExt.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCSExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageAttributes.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageAttributes.scala
index 327fcff0..0753932a 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageAttributes.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageExt.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageExt.scala
index 7fe6279f..e767f527 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageExt.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageSettings.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageSettings.scala
index 1aad3d50..4ca64e15 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageSettings.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/GCStorageSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectAccessControls.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectAccessControls.scala
index 2e1474e1..fdd325be 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectAccessControls.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectAccessControls.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectNotFoundException.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectNotFoundException.scala
index ecbd7444..d9a3a128 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectNotFoundException.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ObjectNotFoundException.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Owner.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Owner.scala
index 9213af0c..2f4b1bed 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Owner.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/Owner.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ProjectTeam.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ProjectTeam.scala
index 1c1c7bfa..ea2e6167 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ProjectTeam.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/ProjectTeam.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageObject.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageObject.scala
index bf6696ea..db1589a2 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageObject.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageObject.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageSettings.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageSettings.scala
index ab8345ea..874a9077 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageSettings.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/StorageSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketInfo.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketInfo.scala
index d6c0a36e..f9d9efd8 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketInfo.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketInfo.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketListResult.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketListResult.scala
index a376ac9e..a39e73d1 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketListResult.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/BucketListResult.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/Formats.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/Formats.scala
index fa9f08c8..024ef972 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/Formats.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/Formats.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/GCStorageStream.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/GCStorageStream.scala
index 60c18bda..052cc56a 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/GCStorageStream.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/GCStorageStream.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/MultiPartUpload.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/MultiPartUpload.scala
index 3b72f875..8b2ef370 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/MultiPartUpload.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/MultiPartUpload.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/RewriteResponse.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/RewriteResponse.scala
index eb04fa99..4e32e9a1 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/RewriteResponse.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/RewriteResponse.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/UploadPartResponse.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/UploadPartResponse.scala
index 5d6f9bde..1c3836f2 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/UploadPartResponse.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/impl/UploadPartResponse.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/javadsl/GCStorage.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/javadsl/GCStorage.scala
index 25254f7c..d27a0da0 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/javadsl/GCStorage.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/javadsl/GCStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/scaladsl/GCStorage.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/scaladsl/GCStorage.scala
index cf06b2e5..ecca3c4e 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/scaladsl/GCStorage.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/scaladsl/GCStorage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/settings.scala b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/settings.scala
index 3b57a998..3770b1f6 100644
--- a/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/settings.scala
+++ b/google-cloud-storage/src/main/scala/akka/stream/alpakka/googlecloud/storage/settings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/java/akka/stream/alpakka/google/javadsl/XUploadContentType.java b/google-common/src/main/java/akka/stream/alpakka/google/javadsl/XUploadContentType.java
index 85a3faf8..62da4d39 100644
--- a/google-common/src/main/java/akka/stream/alpakka/google/javadsl/XUploadContentType.java
+++ b/google-common/src/main/java/akka/stream/alpakka/google/javadsl/XUploadContentType.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleAttributes.scala b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleAttributes.scala
index 32aa8431..aa4c23bc 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleAttributes.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleExt.scala b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleExt.scala
index c8aed5c9..5061219b 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleExt.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleSettings.scala b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleSettings.scala
index 1b6d289b..be940052 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/GoogleSettings.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/GoogleSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/PaginatedRequest.scala b/google-common/src/main/scala/akka/stream/alpakka/google/PaginatedRequest.scala
index 9d31da65..ef7cba5a 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/PaginatedRequest.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/PaginatedRequest.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/ResumableUpload.scala b/google-common/src/main/scala/akka/stream/alpakka/google/ResumableUpload.scala
index 1c555c4e..064009bd 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/ResumableUpload.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/ResumableUpload.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/AccessToken.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/AccessToken.scala
index 46f9b839..3a6b3443 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/AccessToken.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/AccessToken.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/ComputeEngineCredentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/ComputeEngineCredentials.scala
index bc3dc9a3..be951601 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/ComputeEngineCredentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/ComputeEngineCredentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/Credentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/Credentials.scala
index 8500e5c4..8341976a 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/Credentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/Credentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleComputeMetadata.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleComputeMetadata.scala
index 5a06e380..d6f4301b 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleComputeMetadata.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleComputeMetadata.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2.scala
index 5ca85933..88c3d68e 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Credentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Credentials.scala
index ccafa132..ed31151d 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Credentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Credentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Exception.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Exception.scala
index f852e4e8..e163162c 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Exception.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/GoogleOAuth2Exception.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/NoCredentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/NoCredentials.scala
index 02350fd7..c1eb1639 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/NoCredentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/NoCredentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/OAuth2Credentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/OAuth2Credentials.scala
index d89991b7..ec0e3075 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/OAuth2Credentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/OAuth2Credentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/ServiceAccountCredentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/ServiceAccountCredentials.scala
index 3d7de6e5..828a8b7a 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/ServiceAccountCredentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/ServiceAccountCredentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessCredentials.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessCredentials.scala
index 116d4708..2a025e87 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessCredentials.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessCredentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessMetadata.scala b/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessMetadata.scala
index bfa866f3..f9fa0489 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessMetadata.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/auth/UserAccessMetadata.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyHttpsContext.scala b/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyHttpsContext.scala
index 4817b0fe..de2a9f6a 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyHttpsContext.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyHttpsContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyPoolSettings.scala b/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyPoolSettings.scala
index 758db51d..21400cde 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyPoolSettings.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/http/ForwardProxyPoolSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/http/GoogleHttp.scala b/google-common/src/main/scala/akka/stream/alpakka/google/http/GoogleHttp.scala
index a332e962..d6d08cff 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/http/GoogleHttp.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/http/GoogleHttp.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/implicits.scala b/google-common/src/main/scala/akka/stream/alpakka/google/implicits.scala
index 4cfc8205..6ab474e3 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/implicits.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/implicits.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Google.scala b/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Google.scala
index cfeaf3de..f4931c8d 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Google.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Google.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Paginated.scala b/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Paginated.scala
index 6fd3f8a5..1536ee0e 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Paginated.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/javadsl/Paginated.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Google.scala b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Google.scala
index 82718ed6..d8b76a9e 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Google.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Google.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Paginated.scala b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Paginated.scala
index d9415a40..91fd54b8 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Paginated.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/Paginated.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/`X-Upload-Content-Type`.scala b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/`X-Upload-Content-Type`.scala
index e325a41d..862aa764 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/`X-Upload-Content-Type`.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/scaladsl/`X-Upload-Content-Type`.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/util/AnnotateLast.scala b/google-common/src/main/scala/akka/stream/alpakka/google/util/AnnotateLast.scala
index d80aa1bf..e4ebd60b 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/util/AnnotateLast.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/util/AnnotateLast.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/util/EitherFlow.scala b/google-common/src/main/scala/akka/stream/alpakka/google/util/EitherFlow.scala
index 110c8f6e..9d9c5095 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/util/EitherFlow.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/util/EitherFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-common/src/main/scala/akka/stream/alpakka/google/util/Retry.scala b/google-common/src/main/scala/akka/stream/alpakka/google/util/Retry.scala
index 1ff4e122..5c3efef7 100644
--- a/google-common/src/main/scala/akka/stream/alpakka/google/util/Retry.scala
+++ b/google-common/src/main/scala/akka/stream/alpakka/google/util/Retry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmNotificationModels.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmNotificationModels.scala
index 4c9be08e..bfca6b68 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmNotificationModels.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmNotificationModels.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmSettings.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmSettings.scala
index d64e9b71..644d05c7 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmSettings.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/FcmSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmFlows.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmFlows.scala
index 4f56597b..8d7b86d7 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmFlows.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmFlows.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmJsonSupport.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmJsonSupport.scala
index 794fff40..2533ad75 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmJsonSupport.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmJsonSupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmSender.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmSender.scala
index 4c28a11d..060f86b9 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmSender.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/impl/FcmSender.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/javadsl/GoogleFcm.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/javadsl/GoogleFcm.scala
index 1eb47537..36e39cb6 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/javadsl/GoogleFcm.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/javadsl/GoogleFcm.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/scaladsl/GoogleFcm.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/scaladsl/GoogleFcm.scala
index 7b95368c..03d0390c 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/scaladsl/GoogleFcm.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/scaladsl/GoogleFcm.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmFlows.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmFlows.scala
index 550821f9..75928ce1 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmFlows.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmFlows.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmJsonSupport.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmJsonSupport.scala
index 5ce96b2c..5c86ed36 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmJsonSupport.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmJsonSupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmSender.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmSender.scala
index 7c8c546e..dac62bc7 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmSender.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/impl/FcmSender.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/javadsl/GoogleFcm.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/javadsl/GoogleFcm.scala
index e00f57b7..90be1e46 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/javadsl/GoogleFcm.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/javadsl/GoogleFcm.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/AndroidConfig.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/AndroidConfig.scala
index 2dd6d725..173f9f06 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/AndroidConfig.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/AndroidConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/ApnsConfig.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/ApnsConfig.scala
index 7da98def..99b9cbce 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/ApnsConfig.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/ApnsConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/BasicNotification.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/BasicNotification.scala
index f344aade..296de94e 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/BasicNotification.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/BasicNotification.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmNotification.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmNotification.scala
index 526bd0e7..dfce372b 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmNotification.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmNotification.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmOption.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmOption.scala
index 8c46c7e1..a973b78b 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmOption.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmOption.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmResponse.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmResponse.scala
index d0a78524..b3a39402 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmResponse.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/FcmResponse.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/NotificationTarget.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/NotificationTarget.scala
index 24c4ba31..fb049d23 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/NotificationTarget.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/NotificationTarget.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/WebPushConfig.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/WebPushConfig.scala
index 4b1f5db5..20632004 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/WebPushConfig.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/models/WebPushConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/scaladsl/GoogleFcm.scala b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/scaladsl/GoogleFcm.scala
index 5ff00d6d..b7c4375c 100644
--- a/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/scaladsl/GoogleFcm.scala
+++ b/google-fcm/src/main/scala/akka/stream/alpakka/google/firebase/fcm/v1/scaladsl/GoogleFcm.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/HTableSettings.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/HTableSettings.scala
index ecb96db8..f7294045 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/HTableSettings.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/HTableSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseCapabilities.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseCapabilities.scala
index c15759ab..c9409262 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseCapabilities.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseCapabilities.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseFlowStage.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseFlowStage.scala
index de131368..55847dd9 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseFlowStage.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseSourceStage.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseSourceStage.scala
index 539c2fc1..c56cadbc 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseSourceStage.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/impl/HBaseSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/javadsl/HTableStage.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/javadsl/HTableStage.scala
index 263afa4f..7855a88b 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/javadsl/HTableStage.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/javadsl/HTableStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hbase/src/main/scala/akka/stream/alpakka/hbase/scaladsl/HTableStage.scala b/hbase/src/main/scala/akka/stream/alpakka/hbase/scaladsl/HTableStage.scala
index ace7dcd0..5354cead 100644
--- a/hbase/src/main/scala/akka/stream/alpakka/hbase/scaladsl/HTableStage.scala
+++ b/hbase/src/main/scala/akka/stream/alpakka/hbase/scaladsl/HTableStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/HdfsFlowStage.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/HdfsFlowStage.scala
index 81075473..b0e1f29e 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/HdfsFlowStage.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/HdfsFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultRotationStrategy.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultRotationStrategy.scala
index d5925074..979f7655 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultRotationStrategy.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultRotationStrategy.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultSyncStrategy.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultSyncStrategy.scala
index 4989951a..9649b4f5 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultSyncStrategy.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/DefaultSyncStrategy.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/Strategy.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/Strategy.scala
index 92cc4a47..2728e8cc 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/Strategy.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/strategy/Strategy.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/CompressedDataWriter.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/CompressedDataWriter.scala
index 4c9c4224..e834c194 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/CompressedDataWriter.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/CompressedDataWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/DataWriter.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/DataWriter.scala
index 6ea16219..f4b3df33 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/DataWriter.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/DataWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/HdfsWriter.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/HdfsWriter.scala
index 6c52fe3f..81491f3f 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/HdfsWriter.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/HdfsWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/SequenceWriter.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/SequenceWriter.scala
index bd5add3a..5af687ca 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/SequenceWriter.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/impl/writer/SequenceWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsFlow.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsFlow.scala
index a4af190b..0b5743d7 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsFlow.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsSource.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsSource.scala
index 1c906931..52e8f95d 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsSource.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/javadsl/HdfsSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/model.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/model.scala
index 6efbb2e8..2a1dd092 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/model.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsFlow.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsFlow.scala
index a075046a..7e07011e 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsFlow.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsSource.scala b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsSource.scala
index 409ba515..1d5009e3 100644
--- a/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsSource.scala
+++ b/hdfs/src/main/scala/akka/stream/alpakka/hdfs/scaladsl/HdfsSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyHttpsContext.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyHttpsContext.scala
index c674ed8c..6a98e9ba 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyHttpsContext.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyHttpsContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyPoolSettings.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyPoolSettings.scala
index c77b9443..d5f95964 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyPoolSettings.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/ForwardProxyPoolSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettingExt.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettingExt.scala
index 0f3ee90d..a92be61d 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettingExt.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettingExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettings.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettings.scala
index 8dd0145e..203d0688 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettings.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/HmsSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsSession.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsSession.scala
index 674237a2..efb88eea 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsSession.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsTokenApi.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsTokenApi.scala
index 339e13cd..a4accb8b 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsTokenApi.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/HmsTokenApi.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitFlows.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitFlows.scala
index a857d35a..476209c4 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitFlows.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitFlows.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitJsonSupport.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitJsonSupport.scala
index 09fcb566..4b22350e 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitJsonSupport.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitJsonSupport.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitSender.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitSender.scala
index 8e9b2b92..5e4aa6e3 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitSender.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/impl/PushKitSender.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/javadsl/HmsPushKit.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/javadsl/HmsPushKit.scala
index 5108ccfe..abb468a7 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/javadsl/HmsPushKit.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/javadsl/HmsPushKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/AndroidConfig.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/AndroidConfig.scala
index a98760e1..26d34cdc 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/AndroidConfig.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/AndroidConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/ApnsConfig.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/ApnsConfig.scala
index 2e72ba96..7a76c3b7 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/ApnsConfig.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/ApnsConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/BasicNotification.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/BasicNotification.scala
index ddf71108..bb16cbde 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/BasicNotification.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/BasicNotification.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/NotificationTarget.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/NotificationTarget.scala
index c3941868..3fa4bce3 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/NotificationTarget.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/NotificationTarget.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/PushKitNotification.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/PushKitNotification.scala
index b5e92b09..18c91a06 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/PushKitNotification.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/PushKitNotification.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/Response.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/Response.scala
index cd9ba093..ebf27a20 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/Response.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/Response.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/WebConfig.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/WebConfig.scala
index 2c18262c..bb3c159f 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/WebConfig.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/models/WebConfig.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/scaladsl/HmsPushKit.scala b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/scaladsl/HmsPushKit.scala
index 50f0ecca..3fa312b3 100644
--- a/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/scaladsl/HmsPushKit.scala
+++ b/huawei-push-kit/src/main/scala/akka/stream/alpakka/huawei/pushkit/scaladsl/HmsPushKit.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbReadSettings.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbReadSettings.scala
index 5c352a96..2bcd05ff 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbReadSettings.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbReadSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbWriteMessage.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbWriteMessage.scala
index 8c1b4ba1..6b993c7f 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbWriteMessage.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/InfluxDbWriteMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/AlpakkaResultMapperHelper.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/AlpakkaResultMapperHelper.scala
index 095ef157..3ed76fcc 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/AlpakkaResultMapperHelper.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/AlpakkaResultMapperHelper.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbFlowStage.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbFlowStage.scala
index c078884c..5116bc38 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbFlowStage.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbSourceStage.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbSourceStage.scala
index d166667a..19ad9129 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbSourceStage.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/impl/InfluxDbSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbFlow.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbFlow.scala
index 01623961..229b8e09 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbFlow.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSink.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSink.scala
index f68585b3..b3345dbe 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSink.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSource.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSource.scala
index ab4160d2..df55e70d 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSource.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/javadsl/InfluxDbSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbFlow.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbFlow.scala
index 529761cd..c0e06476 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbFlow.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSink.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSink.scala
index 43be5d33..799e4c84 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSink.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSource.scala b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSource.scala
index 90064ac5..6aeae335 100644
--- a/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSource.scala
+++ b/influxdb/src/main/scala/akka/stream/alpakka/influxdb/scaladsl/InfluxDbSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/IronMqSettings.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/IronMqSettings.scala
index 3e59c605..3c5f539f 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/IronMqSettings.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/IronMqSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/domain.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/domain.scala
index d6702de6..60154313 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/domain.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/domain.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/Codec.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/Codec.scala
index 38023f2b..fb8ae9ff 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/Codec.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/Codec.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqClient.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqClient.scala
index 3c1fc388..c8a0f4c0 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqClient.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqClient.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPullStage.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPullStage.scala
index 572955d6..b4cb940d 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPullStage.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPullStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPushStage.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPushStage.scala
index 2a03dfec..bf2d26fa 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPushStage.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/IronMqPushStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/ReservedMessage.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/ReservedMessage.scala
index 7eb09e8d..5e4a1172 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/ReservedMessage.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/impl/ReservedMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/CommittableMessage.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/CommittableMessage.scala
index a24c05ec..9065ef6b 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/CommittableMessage.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/CommittableMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqConsumer.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqConsumer.scala
index 2e1d6f8e..1c96d480 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqConsumer.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqProducer.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqProducer.scala
index 87fd84a5..90a39278 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqProducer.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/IronMqProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/package.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/package.scala
index 4f90a365..e91b87a4 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/package.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/javadsl/package.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/CommittableMessage.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/CommittableMessage.scala
index b784b695..e1221fdd 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/CommittableMessage.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/CommittableMessage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqConsumer.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqConsumer.scala
index 4fc49f24..810599ec 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqConsumer.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqProducer.scala b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqProducer.scala
index 2b026ef2..9096e424 100644
--- a/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqProducer.scala
+++ b/ironmq/src/main/scala/akka/stream/alpakka/ironmq/scaladsl/IronMqProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/AcknowledgeMode.scala b/jms/src/main/scala/akka/stream/alpakka/jms/AcknowledgeMode.scala
index 88908a63..161f82f8 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/AcknowledgeMode.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/AcknowledgeMode.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/ConnectionRetrySettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/ConnectionRetrySettings.scala
index 350d9de7..8a3022c3 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/ConnectionRetrySettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/ConnectionRetrySettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/Credentials.scala b/jms/src/main/scala/akka/stream/alpakka/jms/Credentials.scala
index d5f01777..c2aa3198 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/Credentials.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/Credentials.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/Destinations.scala b/jms/src/main/scala/akka/stream/alpakka/jms/Destinations.scala
index 790d98ef..286c436e 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/Destinations.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/Destinations.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/Envelopes.scala b/jms/src/main/scala/akka/stream/alpakka/jms/Envelopes.scala
index 2cb7e2d8..a7a0773f 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/Envelopes.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/Envelopes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/Headers.scala b/jms/src/main/scala/akka/stream/alpakka/jms/Headers.scala
index 8b74376b..b1a07a6a 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/Headers.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/Headers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsBrowseSettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsBrowseSettings.scala
index 4f9888ca..8712422e 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsBrowseSettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsBrowseSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsConsumerSettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsConsumerSettings.scala
index 3384ab37..506eb25b 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsConsumerSettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsConsumerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsExceptions.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsExceptions.scala
index e9fbc4d6..96e2edf9 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsExceptions.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsExceptions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsMessages.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsMessages.scala
index dc246d17..74bd7bd1 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsMessages.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsMessages.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsProducerSettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsProducerSettings.scala
index 371672d0..9229e06d 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsProducerSettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsProducerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/JmsSettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/JmsSettings.scala
index 2cb51485..ade489e6 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/JmsSettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/JmsSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/SendRetrySettings.scala b/jms/src/main/scala/akka/stream/alpakka/jms/SendRetrySettings.scala
index 4715153e..6f4aaf32 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/SendRetrySettings.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/SendRetrySettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/InternalConnectionState.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/InternalConnectionState.scala
index 351b6db5..ad8e417a 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/InternalConnectionState.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/InternalConnectionState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsAckSourceStage.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsAckSourceStage.scala
index ac0321a0..0e90f571 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsAckSourceStage.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsAckSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsBrowseStage.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsBrowseStage.scala
index 70d71e06..85304227 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsBrowseStage.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsBrowseStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConnector.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConnector.scala
index 62763477..1bc013f5 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConnector.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConnector.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConsumerStage.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConsumerStage.scala
index 3ac991a7..23b9ce55 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConsumerStage.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsConsumerStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsInternalMatValues.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsInternalMatValues.scala
index 84a1d174..2e97cfbc 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsInternalMatValues.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsInternalMatValues.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageProducer.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageProducer.scala
index da0859c3..a3655469 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageProducer.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageReader.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageReader.scala
index 443353c6..71a2b4d0 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageReader.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsMessageReader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsProducerStage.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsProducerStage.scala
index 34794ad6..98329ee5 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsProducerStage.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsProducerStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsTxSourceStage.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsTxSourceStage.scala
index 73d5a924..2733d447 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsTxSourceStage.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/JmsTxSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/Sessions.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/Sessions.scala
index 270350bb..948fe516 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/Sessions.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/Sessions.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/SoftReferenceCache.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/SoftReferenceCache.scala
index d94f9324..0d443a90 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/SoftReferenceCache.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/SoftReferenceCache.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/impl/SourceStageLogic.scala b/jms/src/main/scala/akka/stream/alpakka/jms/impl/SourceStageLogic.scala
index 15490421..44ff344c 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/impl/SourceStageLogic.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/impl/SourceStageLogic.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConnectorState.java b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConnectorState.java
index 9f522f46..6779b6e1 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConnectorState.java
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConnectorState.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumer.scala b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumer.scala
index 0859964f..37a55a52 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumer.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumerControl.java b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumerControl.java
index 880b0f65..f9582ec0 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumerControl.java
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsConsumerControl.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducer.scala b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducer.scala
index 056576cc..77e7830a 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducer.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducerStatus.java b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducerStatus.java
index 64e5d110..9de2a7ea 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducerStatus.java
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/javadsl/JmsProducerStatus.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConnectorState.scala b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConnectorState.scala
index 008260c6..b33ed38d 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConnectorState.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConnectorState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConsumer.scala b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConsumer.scala
index b5b1e2cd..f9e19a92 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConsumer.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsConsumer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsProducer.scala b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsProducer.scala
index bfe02fdb..d1451dc3 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsProducer.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/JmsProducer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/package.scala b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/package.scala
index 7dee72af..e1d1612c 100644
--- a/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/package.scala
+++ b/jms/src/main/scala/akka/stream/alpakka/jms/scaladsl/package.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/json-streaming/src/main/scala/akka/stream/alpakka/json/impl/JsonStreamReader.scala b/json-streaming/src/main/scala/akka/stream/alpakka/json/impl/JsonStreamReader.scala
index 6cb76526..88525aea 100644
--- a/json-streaming/src/main/scala/akka/stream/alpakka/json/impl/JsonStreamReader.scala
+++ b/json-streaming/src/main/scala/akka/stream/alpakka/json/impl/JsonStreamReader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/json-streaming/src/main/scala/akka/stream/alpakka/json/javadsl/JsonReader.scala b/json-streaming/src/main/scala/akka/stream/alpakka/json/javadsl/JsonReader.scala
index 8beab098..9af99485 100644
--- a/json-streaming/src/main/scala/akka/stream/alpakka/json/javadsl/JsonReader.scala
+++ b/json-streaming/src/main/scala/akka/stream/alpakka/json/javadsl/JsonReader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/json-streaming/src/main/scala/akka/stream/alpakka/json/scaladsl/JsonReader.scala b/json-streaming/src/main/scala/akka/stream/alpakka/json/scaladsl/JsonReader.scala
index 6be32859..b0feff77 100644
--- a/json-streaming/src/main/scala/akka/stream/alpakka/json/scaladsl/JsonReader.scala
+++ b/json-streaming/src/main/scala/akka/stream/alpakka/json/scaladsl/JsonReader.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/CommittableRecord.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/CommittableRecord.scala
index 201d5902..f7fb1e5d 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/CommittableRecord.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/CommittableRecord.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisErrors.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisErrors.scala
index f1f8ed8c..51c5044b 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisErrors.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisErrors.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisFlowSettings.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisFlowSettings.scala
index 9d7a3ca4..4902383c 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisFlowSettings.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisFlowSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerErrors.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerErrors.scala
index 514876f1..9e63e6e7 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerErrors.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerErrors.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerSettings.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerSettings.scala
index abe83445..117e12ae 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerSettings.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/KinesisSchedulerSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardIterator.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardIterator.scala
index ad72395b..9dec8c97 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardIterator.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardIterator.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardSettings.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardSettings.scala
index 6736009e..fc733050 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardSettings.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/ShardSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSchedulerSourceStage.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSchedulerSourceStage.scala
index 643c1be5..0e21d0c2 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSchedulerSourceStage.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSchedulerSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSourceStage.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSourceStage.scala
index e0ae43eb..68a91f0d 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSourceStage.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/KinesisSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/ShardProcessor.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/ShardProcessor.scala
index 7e4d773c..7a02d491 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/ShardProcessor.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/impl/ShardProcessor.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisFlow.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisFlow.scala
index 051d7fa2..cafb5a66 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisFlow.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSchedulerSource.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSchedulerSource.scala
index b238e6a6..1483e45e 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSchedulerSource.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSchedulerSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSink.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSink.scala
index 0a8489b7..995c9a84 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSink.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSource.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSource.scala
index 7572d385..88cdb61b 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSource.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/javadsl/KinesisSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisFlow.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisFlow.scala
index decda96f..17ba875c 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisFlow.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSchedulerSource.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSchedulerSource.scala
index 8d5a27e5..e99e4c16 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSchedulerSource.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSchedulerSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSink.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSink.scala
index 93742db7..84bcaef0 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSink.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSource.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSource.scala
index 36384f2c..fe469e05 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSource.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesis/scaladsl/KinesisSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseErrors.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseErrors.scala
index d5176321..d55ef800 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseErrors.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseErrors.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseFlowSettings.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseFlowSettings.scala
index 8e7404e3..117029d0 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseFlowSettings.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/KinesisFirehoseFlowSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseFlow.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseFlow.scala
index 7287ebf2..cd61d4a0 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseFlow.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseSink.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseSink.scala
index 060b98b6..3ef8c263 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseSink.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/javadsl/KinesisFirehoseSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseFlow.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseFlow.scala
index d8262643..11d55a39 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseFlow.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseSink.scala b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseSink.scala
index a6b8f527..ebb4db90 100644
--- a/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseSink.scala
+++ b/kinesis/src/main/scala/akka/stream/alpakka/kinesisfirehose/scaladsl/KinesisFirehoseSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduAttributes.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduAttributes.scala
index 8e606f8a..32e8aa70 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduAttributes.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduAttributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduClientExt.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduClientExt.scala
index 8046ef1b..a75931fb 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduClientExt.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduClientExt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduTableSettings.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduTableSettings.scala
index c085f990..96b3dffe 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduTableSettings.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/KuduTableSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduCapabilities.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduCapabilities.scala
index cd7ae1e4..7a7be168 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduCapabilities.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduCapabilities.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduFlowStage.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduFlowStage.scala
index 3bbd8ac4..7d908119 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduFlowStage.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/impl/KuduFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/javadsl/KuduTable.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/javadsl/KuduTable.scala
index 3be8eadf..d64c0232 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/javadsl/KuduTable.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/javadsl/KuduTable.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/kudu/src/main/scala/akka/stream/alpakka/kudu/scaladsl/KuduTable.scala b/kudu/src/main/scala/akka/stream/alpakka/kudu/scaladsl/KuduTable.scala
index 9265aa98..950f407d 100644
--- a/kudu/src/main/scala/akka/stream/alpakka/kudu/scaladsl/KuduTable.scala
+++ b/kudu/src/main/scala/akka/stream/alpakka/kudu/scaladsl/KuduTable.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentReplace.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentReplace.scala
index 211650de..52ecac2d 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentReplace.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentReplace.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentUpdate.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentUpdate.scala
index 2d06725b..56968a13 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentUpdate.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/DocumentUpdate.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoFlow.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoFlow.scala
index 7c029e8f..a33b36aa 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoFlow.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSink.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSink.scala
index f03953ad..5934d935 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSink.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSource.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSource.scala
index bdd1a965..e6da25c4 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSource.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/javadsl/MongoSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoFlow.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoFlow.scala
index 3d16bedb..00f42937 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoFlow.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSink.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSink.scala
index b6539b64..b69d4c39 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSink.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSource.scala b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSource.scala
index 224ed39b..7904df56 100644
--- a/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSource.scala
+++ b/mongodb/src/main/scala/akka/stream/alpakka/mongodb/scaladsl/MongoSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/MqttSessionSettings.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/MqttSessionSettings.scala
index 7de3eaa8..82c2521b 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/MqttSessionSettings.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/MqttSessionSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ActorName.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ActorName.scala
index 69c2d761..d7d636b6 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ActorName.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ActorName.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/BehaviorRunner.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/BehaviorRunner.scala
index 082f2993..db71c69a 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/BehaviorRunner.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/BehaviorRunner.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ClientState.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ClientState.scala
index 0bf1f3e4..200bf2e3 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ClientState.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ClientState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/MqttFrameStage.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/MqttFrameStage.scala
index b547bbfa..6f70dcec 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/MqttFrameStage.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/MqttFrameStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/QueueOfferState.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/QueueOfferState.scala
index 028c8ee5..494a4d70 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/QueueOfferState.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/QueueOfferState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/RequestState.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/RequestState.scala
index c5c2e410..dc6473d4 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/RequestState.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/RequestState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ServerState.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ServerState.scala
index 3c749a4e..51100115 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ServerState.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/impl/ServerState.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/Mqtt.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/Mqtt.scala
index 407fdaac..d8d26114 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/Mqtt.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/Mqtt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/MqttSession.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/MqttSession.scala
index 52864d56..4351f2ae 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/MqttSession.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/javadsl/MqttSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/model.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/model.scala
index 9587e47d..7ecabc16 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/model.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/Mqtt.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/Mqtt.scala
index c402ea26..63e8e6d7 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/Mqtt.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/Mqtt.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/MqttSession.scala b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/MqttSession.scala
index e0f96286..c0e54048 100644
--- a/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/MqttSession.scala
+++ b/mqtt-streaming/src/main/scala/akka/stream/alpakka/mqtt/streaming/scaladsl/MqttSession.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStage.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStage.scala
index bc969776..c48dfe4f 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStage.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStageWithAck.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStageWithAck.scala
index 011cdc07..e72f316a 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStageWithAck.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/impl/MqttFlowStageWithAck.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttFlow.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttFlow.scala
index a4e8aabd..c90abd5d 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttFlow.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttMessageWithAck.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttMessageWithAck.scala
index d8c20ece..031434f3 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttMessageWithAck.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttMessageWithAck.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSink.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSink.scala
index 7380da2f..c3b9f880 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSink.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSource.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSource.scala
index 12e3efcd..898badff 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSource.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/javadsl/MqttSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/model.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/model.scala
index 14150222..d5f42564 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/model.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttFlow.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttFlow.scala
index 720fdc21..8e101bd9 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttFlow.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttMessageWithAck.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttMessageWithAck.scala
index 864a6ff2..acc2192e 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttMessageWithAck.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttMessageWithAck.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSink.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSink.scala
index 137e71cc..bd0e11fb 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSink.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSource.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSource.scala
index 99483622..4bc26b06 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSource.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/scaladsl/MqttSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/settings.scala b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/settings.scala
index a27c4b46..d6f31051 100644
--- a/mqtt/src/main/scala/akka/stream/alpakka/mqtt/settings.scala
+++ b/mqtt/src/main/scala/akka/stream/alpakka/mqtt/settings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbSourceSettings.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbSourceSettings.scala
index 171e72d9..6c983b6c 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbSourceSettings.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbSourceSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbWriteSettings.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbWriteSettings.scala
index 53cc955b..18c50444 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbWriteSettings.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/OrientDbWriteSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbFlowStage.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbFlowStage.scala
index c635e27f..7369f441 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbFlowStage.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbSourceStage.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbSourceStage.scala
index 4d05dd29..a34990f9 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbSourceStage.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/impl/OrientDbSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbFlow.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbFlow.scala
index 0617eb6a..6147fecf 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbFlow.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSink.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSink.scala
index ad61dd5c..11c4bcb5 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSink.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSource.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSource.scala
index f282012b..c3b636e1 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSource.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/javadsl/OrientDbSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/model.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/model.scala
index 9e41ac4d..41632ba3 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/model.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbFlow.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbFlow.scala
index ae4d0f3b..eb0dd0df 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbFlow.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSink.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSink.scala
index d4770a1c..2bb0d250 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSink.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSink.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSource.scala b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSource.scala
index 77ef3b16..fe161a20 100644
--- a/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSource.scala
+++ b/orientdb/src/main/scala/akka/stream/alpakka/orientdb/scaladsl/OrientDbSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/Pravega.java b/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/Pravega.java
index 62307199..76d7f565 100644
--- a/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/Pravega.java
+++ b/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/Pravega.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/PravegaTable.java b/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/PravegaTable.java
index 4dc1f4ac..095a3dbe 100644
--- a/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/PravegaTable.java
+++ b/pravega/src/main/java/akka/stream/alpakka/pravega/javadsl/PravegaTable.java
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaEvent.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaEvent.scala
index 224b9859..db152d13 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaEvent.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaEvent.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaReaderGroupManager.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaReaderGroupManager.scala
index ebdf1125..67fa3190 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaReaderGroupManager.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaReaderGroupManager.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaSettings.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaSettings.scala
index 9bd6519e..a8fe1eb0 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaSettings.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/PravegaSettings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/TableEntry.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/TableEntry.scala
index 6591f686..6baa15e3 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/TableEntry.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/TableEntry.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaCapabilities.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaCapabilities.scala
index afa4264e..26afc1e8 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaCapabilities.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaCapabilities.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaFlow.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaFlow.scala
index 32b68f10..4a7aa640 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaFlow.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaSource.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaSource.scala
index 0442cd5c..c18c8e66 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaSource.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableReadFlow.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableReadFlow.scala
index f44dfa32..7df88cd6 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableReadFlow.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableReadFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
@@ -44,7 +53,7 @@ import scala.util.Success
   @volatile
   private var upstreamEnded = false;
 
-  private val asyncMessageSendCallback: AsyncCallback[(Try[TableEntry])] = getAsyncCallback { p =>
+  private val asyncMessageSendCallback: AsyncCallback[Try[TableEntry]] = getAsyncCallback { p =>
     p match {
       case Failure(exception) =>
         log.error(exception, s"Failed to send message {}")
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableSource.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableSource.scala
index 9d224849..e4d21f3f 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableSource.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableSource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableWriteFlow.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableWriteFlow.scala
index e643c782..98008439 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableWriteFlow.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaTableWriteFlow.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaWriter.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaWriter.scala
index be51b8b6..6bb7642e 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaWriter.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/impl/PravegaWriter.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/Pravega.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/Pravega.scala
index d062c300..aa41f9d2 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/Pravega.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/Pravega.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/PravegaTable.scala b/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/PravegaTable.scala
index 63d4aae5..3782167f 100644
--- a/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/PravegaTable.scala
+++ b/pravega/src/main/scala/akka/stream/alpakka/pravega/scaladsl/PravegaTable.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/project/Common.scala b/project/Common.scala
index b7186fc3..7ff912d3 100644
--- a/project/Common.scala
+++ b/project/Common.scala
@@ -113,7 +113,5 @@ object Common extends AutoPlugin {
     Test / testOptions += Tests.Argument(TestFrameworks.ScalaTest, "-F", "4"),
     scalafmtOnCompile := false,
     javafmtOnCompile := false,
-    headerLicense := Some(HeaderLicense.Custom(
-      "Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>")),
     sonatypeProfileName := "org.apache.pekko")
 }
diff --git a/project/CopyrightHeader.scala b/project/CopyrightHeader.scala
new file mode 100644
index 00000000..98561c88
--- /dev/null
+++ b/project/CopyrightHeader.scala
@@ -0,0 +1,90 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
+/*
+ * Copyright (C) 2018-2022 Lightbend Inc. <https://www.lightbend.com>
+ */
+
+import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport._
+import de.heikoseeberger.sbtheader.{ CommentCreator, HeaderPlugin, NewLine }
+import org.apache.commons.lang3.StringUtils
+import sbt.Keys._
+import sbt._
+
+trait CopyrightHeader extends AutoPlugin {
+
+  override def requires: Plugins = HeaderPlugin
+
+  override def trigger: PluginTrigger = allRequirements
+
+  protected def headerMappingSettings: Seq[Def.Setting[_]] =
+    Seq(Compile, Test).flatMap { config =>
+      inConfig(config)(
+        Seq(
+          headerLicense := Some(HeaderLicense.Custom(apacheHeader)),
+          headerMappings := headerMappings.value ++ Map(
+            HeaderFileType.scala -> cStyleComment,
+            HeaderFileType.java -> cStyleComment,
+            HeaderFileType("template") -> cStyleComment)))
+    }
+
+  override def projectSettings: Seq[Def.Setting[_]] = Def.settings(headerMappingSettings, additional)
+
+  def additional: Seq[Def.Setting[_]] =
+    Def.settings(Compile / compile := {
+        (Compile / headerCreate).value
+        (Compile / compile).value
+      },
+      Test / compile := {
+        (Test / headerCreate).value
+        (Test / compile).value
+      })
+
+  val apacheHeader: String =
+    """Licensed to the Apache Software Foundation (ASF) under one or more
+      |license agreements; and to You under the Apache License, version 2.0:
+      |
+      |  https://www.apache.org/licenses/LICENSE-2.0
+      |
+      |This file is part of the Apache Pekko project, derived from Akka.
+      |""".stripMargin
+
+  val cStyleComment = HeaderCommentStyle.cStyleBlockComment.copy(commentCreator = new CommentCreator() {
+
+    override def apply(text: String, existingText: Option[String]): String = {
+      val formatted = existingText match {
+        case Some(currentText) if isApacheCopyrighted(currentText) || isGenerated(currentText) =>
+          currentText
+        case Some(currentText) if isOnlyLightbendCopyrightAnnotated(currentText) =>
+          HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText) + NewLine * 2 + currentText
+        case Some(currentText) =>
+          throw new IllegalStateException(s"Unable to detect copyright for header: [${currentText}]")
+        case None =>
+          HeaderCommentStyle.cStyleBlockComment.commentCreator(text, existingText)
+      }
+      formatted.trim
+    }
+  })
+
+  private def isGenerated(text: String): Boolean =
+    StringUtils.contains(text, "DO NOT EDIT DIRECTLY")
+
+  private def isApacheCopyrighted(text: String): Boolean =
+    StringUtils.containsIgnoreCase(text, "licensed to the apache software foundation (asf)") ||
+    StringUtils.containsIgnoreCase(text, "www.apache.org/licenses/license-2.0")
+
+  private def isLightbendCopyrighted(text: String): Boolean =
+    StringUtils.containsIgnoreCase(text, "lightbend inc.")
+
+  private def isOnlyLightbendCopyrightAnnotated(text: String): Boolean = {
+    isLightbendCopyrighted(text) && !isApacheCopyrighted(text)
+  }
+}
+
+object CopyrightHeader extends CopyrightHeader
diff --git a/project/CopyrightHeaderForBuild.scala b/project/CopyrightHeaderForBuild.scala
new file mode 100644
index 00000000..5f5c36ad
--- /dev/null
+++ b/project/CopyrightHeaderForBuild.scala
@@ -0,0 +1,30 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
+/*
+ * Copyright (C) 2019-2022 Lightbend Inc. <https://www.lightbend.com>
+ */
+
+import de.heikoseeberger.sbtheader.HeaderPlugin.autoImport.{ headerMappings, headerSources, HeaderFileType }
+import sbt.Keys.baseDirectory
+import sbt.{ inConfig, Compile, Def, PluginTrigger, Test, _ }
+
+object CopyrightHeaderForBuild extends CopyrightHeader {
+  override def trigger: PluginTrigger = noTrigger
+
+  override def projectSettings: Seq[Def.Setting[_]] = {
+    Seq(Compile, Test).flatMap { config =>
+      inConfig(config) {
+        Seq(
+          config / headerSources ++= (((config / baseDirectory).value / "project") ** "*.scala").get,
+          headerMappings := headerMappings.value ++ Map(HeaderFileType.scala -> cStyleComment))
+      }
+    }
+  }
+}
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/Resource.scala b/reference/src/main/scala/akka/stream/alpakka/reference/Resource.scala
index 54dca1f4..d6d52128 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/Resource.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/Resource.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/attributes.scala b/reference/src/main/scala/akka/stream/alpakka/reference/attributes.scala
index aacf7aac..16e2d70c 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/attributes.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/attributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceFlowStage.scala b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceFlowStage.scala
index 60afb4b1..dcf92c2d 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceFlowStage.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceSourceStage.scala b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceSourceStage.scala
index 08f1b50e..042f1e40 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceSourceStage.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceSourceStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceWithResourceFlowStage.scala b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceWithResourceFlowStage.scala
index e8c842f2..acd2f9a6 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceWithResourceFlowStage.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/impl/ReferenceWithResourceFlowStage.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/javadsl/Reference.scala b/reference/src/main/scala/akka/stream/alpakka/reference/javadsl/Reference.scala
index 899e4ba0..ba077969 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/javadsl/Reference.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/javadsl/Reference.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/model.scala b/reference/src/main/scala/akka/stream/alpakka/reference/model.scala
index 8e038352..f65fd1fe 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/model.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/model.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/scaladsl/Reference.scala b/reference/src/main/scala/akka/stream/alpakka/reference/scaladsl/Reference.scala
index eb835d49..3a290c8c 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/scaladsl/Reference.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/scaladsl/Reference.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/settings.scala b/reference/src/main/scala/akka/stream/alpakka/reference/settings.scala
index fbcdb067..07704d00 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/settings.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/settings.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/reference/src/main/scala/akka/stream/alpakka/reference/testkit/MessageFactory.scala b/reference/src/main/scala/akka/stream/alpakka/reference/testkit/MessageFactory.scala
index 1b5ecdcc..d5c9ad69 100644
--- a/reference/src/main/scala/akka/stream/alpakka/reference/testkit/MessageFactory.scala
+++ b/reference/src/main/scala/akka/stream/alpakka/reference/testkit/MessageFactory.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/S3Attributes.scala b/s3/src/main/scala/akka/stream/alpakka/s3/S3Attributes.scala
index b287446f..4e06aded 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/S3Attributes.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/S3Attributes.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/S3Exception.scala b/s3/src/main/scala/akka/stream/alpakka/s3/S3Exception.scala
index c09492f1..4a3e28d2 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/S3Exception.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/S3Exception.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/S3Ext.scala b/s3/src/main/scala/akka/stream/alpakka/s3/S3Ext.scala
index e8880b70..915a04ed 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/S3Ext.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/S3Ext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/S3Headers.scala b/s3/src/main/scala/akka/stream/alpakka/s3/S3Headers.scala
index f486da0e..c1148a24 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/S3Headers.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/S3Headers.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/Utils.scala b/s3/src/main/scala/akka/stream/alpakka/s3/Utils.scala
index bd94ac53..138dcf8d 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/Utils.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/Utils.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/headers/CannedAcl.scala b/s3/src/main/scala/akka/stream/alpakka/s3/headers/CannedAcl.scala
index ecd1d199..615be25f 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/headers/CannedAcl.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/headers/CannedAcl.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/headers/ServerSideEncryption.scala b/s3/src/main/scala/akka/stream/alpakka/s3/headers/ServerSideEncryption.scala
index aa5c5231..a49101a7 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/headers/ServerSideEncryption.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/headers/ServerSideEncryption.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/headers/StorageClass.scala b/s3/src/main/scala/akka/stream/alpakka/s3/headers/StorageClass.scala
index 85d1a258..3a330fb5 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/headers/StorageClass.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/headers/StorageClass.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/Chunk.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/Chunk.scala
index 969ee434..98f74d87 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/Chunk.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/Chunk.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/DiskBuffer.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/DiskBuffer.scala
index ed0ea10f..ceaf0d50 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/DiskBuffer.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/DiskBuffer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/HttpRequests.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/HttpRequests.scala
index 2c24d005..e4978450 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/HttpRequests.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/HttpRequests.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/Marshalling.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/Marshalling.scala
index 34e6c150..7e94e3e1 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/Marshalling.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/Marshalling.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryBuffer.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryBuffer.scala
index e9cfc708..295b9d73 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryBuffer.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryBuffer.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryWithContext.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryWithContext.scala
index dc646cda..65c395d4 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryWithContext.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/MemoryWithContext.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Request.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Request.scala
index 61c3be2e..8debb3b0 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Request.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Request.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
  * Copyright (C) since 2016 Lightbend Inc. <https://www.lightbend.com>
  */
diff --git a/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Stream.scala b/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Stream.scala
index 8fcc31ff..48ef9e03 100644
--- a/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Stream.scala
+++ b/s3/src/main/scala/akka/stream/alpakka/s3/impl/S3Stream.scala
@@ -1,3 +1,12 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * license agreements; and to You under the Apache License, version 2.0:
+ *
+ *   https://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This file is part of the Apache Pekko project, derived from Akka.
+ */
+
 /*
... 1401 lines suppressed ...


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