You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kvrocks.apache.org by ti...@apache.org on 2022/04/30 07:20:50 UTC

[incubator-kvrocks] branch unstable updated: Apply Apache License header for Tcl files (#548)

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

tison pushed a commit to branch unstable
in repository https://gitbox.apache.org/repos/asf/incubator-kvrocks.git


The following commit(s) were added to refs/heads/unstable by this push:
     new fca9e69  Apply Apache License header for Tcl files (#548)
fca9e69 is described below

commit fca9e6962be5e85ad659545d94b5dafa4aec1325
Author: tison <wa...@gmail.com>
AuthorDate: Sat Apr 30 15:20:45 2022 +0800

    Apply Apache License header for Tcl files (#548)
    
    Signed-off-by: tison <wa...@gmail.com>
---
 NOTICE                                      |  5 +++++
 licenses/LICENSE.redis                      | 10 ++++++++++
 tests/tcl/tests/helpers/bg_block_op.tcl     | 23 +++++++++++++++++++++++
 tests/tcl/tests/helpers/bg_complex_data.tcl | 23 +++++++++++++++++++++++
 tests/tcl/tests/helpers/crc16_slottable.tcl | 17 +++++++++++++++++
 tests/tcl/tests/helpers/gen_write_load.tcl  | 23 +++++++++++++++++++++++
 tests/tcl/tests/instances.tcl               | 27 +++++++++++++++++++++++----
 tests/tcl/tests/integration/cluster.tcl     | 17 +++++++++++++++++
 tests/tcl/tests/integration/redis-cli.tcl   | 23 +++++++++++++++++++++++
 tests/tcl/tests/integration/replication.tcl | 23 +++++++++++++++++++++++
 tests/tcl/tests/integration/slotimport.tcl  | 17 +++++++++++++++++
 tests/tcl/tests/integration/slotmigrate.tcl | 17 +++++++++++++++++
 tests/tcl/tests/support/benchmark.tcl       | 23 +++++++++++++++++++++++
 tests/tcl/tests/support/cli.tcl             | 23 +++++++++++++++++++++++
 tests/tcl/tests/support/cluster.tcl         | 25 +++++++++++++++++++++++--
 tests/tcl/tests/support/redis.tcl           | 25 +++++++++++++++++++++++--
 tests/tcl/tests/support/server.tcl          | 23 +++++++++++++++++++++++
 tests/tcl/tests/support/test.tcl            | 23 +++++++++++++++++++++++
 tests/tcl/tests/support/tmpfile.tcl         | 23 +++++++++++++++++++++++
 tests/tcl/tests/support/util.tcl            | 23 +++++++++++++++++++++++
 tests/tcl/tests/test_helper.tcl             | 27 ++++++++++++++++++++++++---
 tests/tcl/tests/unit/acl.tcl                | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/auth.tcl               | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/bitfield.tcl           | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/bitops.tcl             | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/command.tcl            | 17 +++++++++++++++++
 tests/tcl/tests/unit/config.tcl             | 19 +++++++++++++++++--
 tests/tcl/tests/unit/expire.tcl             | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/geo.tcl                | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/hyperloglog.tcl        | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/introspection.tcl      | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/keyspace.tcl           | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/limits.tcl             | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/multi.tcl              | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/protocol.tcl           | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/pubsub.tcl             | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/quit.tcl               | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/scan.tcl               | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/scripting.tcl          | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/slowlog.tcl            | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/tls.tcl                | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/bitmap.tcl        | 17 +++++++++++++++++
 tests/tcl/tests/unit/type/hash.tcl          | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/incr.tcl          | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/list-2.tcl        | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/list-3.tcl        | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/list-common.tcl   | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/list.tcl          | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/set.tcl           | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/sint.tcl          | 17 +++++++++++++++++
 tests/tcl/tests/unit/type/string.tcl        | 23 +++++++++++++++++++++++
 tests/tcl/tests/unit/type/zset.tcl          | 23 +++++++++++++++++++++++
 tools/ci/licenserc.yml                      |  1 +
 53 files changed, 1119 insertions(+), 13 deletions(-)

diff --git a/NOTICE b/NOTICE
new file mode 100644
index 0000000..bb54855
--- /dev/null
+++ b/NOTICE
@@ -0,0 +1,5 @@
+Apache Kvrocks (Incubating)
+Copyright 2022 The Apache Software Foundation
+
+This product includes software developed at
+The Apache Software Foundation (http://www.apache.org/).
diff --git a/licenses/LICENSE.redis b/licenses/LICENSE.redis
new file mode 100644
index 0000000..a381681
--- /dev/null
+++ b/licenses/LICENSE.redis
@@ -0,0 +1,10 @@
+Copyright (c) 2006-2020, Salvatore Sanfilippo
+All rights reserved.
+
+Redistribution and use in source and binary forms, with or without modification, are permitted provided that the following conditions are met:
+
+    * Redistributions of source code must retain the above copyright notice, this list of conditions and the following disclaimer.
+    * Redistributions in binary form must reproduce the above copyright notice, this list of conditions and the following disclaimer in the documentation and/or other materials provided with the distribution.
+    * Neither the name of Redis nor the names of its contributors may be used to endorse or promote products derived from this software without specific prior written permission.
+
+THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFI [...]
diff --git a/tests/tcl/tests/helpers/bg_block_op.tcl b/tests/tcl/tests/helpers/bg_block_op.tcl
index c8b3233..790e420 100644
--- a/tests/tcl/tests/helpers/bg_block_op.tcl
+++ b/tests/tcl/tests/helpers/bg_block_op.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/helpers/bg_block_op.tcl
+
 source tests/support/redis.tcl
 source tests/support/util.tcl
 
diff --git a/tests/tcl/tests/helpers/bg_complex_data.tcl b/tests/tcl/tests/helpers/bg_complex_data.tcl
index e888748..9581795 100644
--- a/tests/tcl/tests/helpers/bg_complex_data.tcl
+++ b/tests/tcl/tests/helpers/bg_complex_data.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/helpers/bg_complex_data.tcl
+
 source tests/support/redis.tcl
 source tests/support/util.tcl
 
diff --git a/tests/tcl/tests/helpers/crc16_slottable.tcl b/tests/tcl/tests/helpers/crc16_slottable.tcl
index 32e51b6..e3015a5 100644
--- a/tests/tcl/tests/helpers/crc16_slottable.tcl
+++ b/tests/tcl/tests/helpers/crc16_slottable.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 # A table of the shortest possible alphanumeric string that is mapped by
 # redis' crc16  to any given redis cluster slot.
 #
diff --git a/tests/tcl/tests/helpers/gen_write_load.tcl b/tests/tcl/tests/helpers/gen_write_load.tcl
index cbf6651..030b126 100644
--- a/tests/tcl/tests/helpers/gen_write_load.tcl
+++ b/tests/tcl/tests/helpers/gen_write_load.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/helpers/gen_write_load.tcl
+
 source tests/support/redis.tcl
 
 set ::tlsdir "tests/tls"
diff --git a/tests/tcl/tests/instances.tcl b/tests/tcl/tests/instances.tcl
index b9d1b3f..550f637 100644
--- a/tests/tcl/tests/instances.tcl
+++ b/tests/tcl/tests/instances.tcl
@@ -1,11 +1,30 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2014, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/instances.tcl
+
 # Multi-instance test framework.
 # This is used in order to test Sentinel and Redis Cluster, and provides
 # basic capabilities for spawning and handling N parallel Redis / Sentinel
 # instances.
-#
-# Copyright (C) 2014 Salvatore Sanfilippo antirez@gmail.com
-# This software is released under the BSD License. See the COPYING file for
-# more information.
 
 package require Tcl 8.5
 
diff --git a/tests/tcl/tests/integration/cluster.tcl b/tests/tcl/tests/integration/cluster.tcl
index 3aed4be..5b3f639 100644
--- a/tests/tcl/tests/integration/cluster.tcl
+++ b/tests/tcl/tests/integration/cluster.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 source "tests/helpers/crc16_slottable.tcl"
 
 start_server {tags {"disable-cluster"}} {
diff --git a/tests/tcl/tests/integration/redis-cli.tcl b/tests/tcl/tests/integration/redis-cli.tcl
index f128fd3..ab60ade 100644
--- a/tests/tcl/tests/integration/redis-cli.tcl
+++ b/tests/tcl/tests/integration/redis-cli.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/integration/redis-cli.tcl
+
 source tests/support/cli.tcl
 
 start_server {tags {"cli"}} {
diff --git a/tests/tcl/tests/integration/replication.tcl b/tests/tcl/tests/integration/replication.tcl
index cdce19e..09135af 100644
--- a/tests/tcl/tests/integration/replication.tcl
+++ b/tests/tcl/tests/integration/replication.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/integration/replication.tcl
+
 start_server {tags {"repl"}} {
     set A [srv 0 client]
     set A_host "localhost"
diff --git a/tests/tcl/tests/integration/slotimport.tcl b/tests/tcl/tests/integration/slotimport.tcl
index 19d7318..3365bb3 100644
--- a/tests/tcl/tests/integration/slotimport.tcl
+++ b/tests/tcl/tests/integration/slotimport.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 # Import crc16 table
 source "tests/helpers/crc16_slottable.tcl"
 
diff --git a/tests/tcl/tests/integration/slotmigrate.tcl b/tests/tcl/tests/integration/slotmigrate.tcl
index 73bb929..aacc578 100644
--- a/tests/tcl/tests/integration/slotmigrate.tcl
+++ b/tests/tcl/tests/integration/slotmigrate.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 # Import crc16 table
 source "tests/helpers/crc16_slottable.tcl"
 
diff --git a/tests/tcl/tests/support/benchmark.tcl b/tests/tcl/tests/support/benchmark.tcl
index 3d08b76..8062221 100644
--- a/tests/tcl/tests/support/benchmark.tcl
+++ b/tests/tcl/tests/support/benchmark.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/benchmark.tcl
+
 proc redisbenchmark_tls_config {testsdir} {
     set tlsdir [file join $testsdir tls]
     set cert [file join $tlsdir client.crt]
diff --git a/tests/tcl/tests/support/cli.tcl b/tests/tcl/tests/support/cli.tcl
index e851afe..abf43d9 100644
--- a/tests/tcl/tests/support/cli.tcl
+++ b/tests/tcl/tests/support/cli.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/cli.tcl
+
 proc rediscli_tls_config {testsdir} {
     set tlsdir [file join $testsdir tls]
     set cert [file join $tlsdir client.crt]
diff --git a/tests/tcl/tests/support/cluster.tcl b/tests/tcl/tests/support/cluster.tcl
index fb8c46e..9f895f7 100644
--- a/tests/tcl/tests/support/cluster.tcl
+++ b/tests/tcl/tests/support/cluster.tcl
@@ -1,6 +1,27 @@
-# Tcl redis cluster client as a wrapper of redis.rb.
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 # Copyright (C) 2014 Salvatore Sanfilippo
-# Released under the BSD license like Redis itself
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/cli.tcl
+
+# Tcl redis cluster client as a wrapper of redis.rb.
 #
 # Example usage:
 #
diff --git a/tests/tcl/tests/support/redis.tcl b/tests/tcl/tests/support/redis.tcl
index 1c3da26..5f432e7 100644
--- a/tests/tcl/tests/support/redis.tcl
+++ b/tests/tcl/tests/support/redis.tcl
@@ -1,6 +1,27 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2009-2014, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/redis.tcl
+
 # Tcl client library - used by the Redis test
-# Copyright (C) 2009-2014 Salvatore Sanfilippo
-# Released under the BSD license like Redis itself
 #
 # Example usage:
 #
diff --git a/tests/tcl/tests/support/server.tcl b/tests/tcl/tests/support/server.tcl
index 716cb8a..7504eb5 100644
--- a/tests/tcl/tests/support/server.tcl
+++ b/tests/tcl/tests/support/server.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/server.tcl
+
 set ::global_overrides {}
 set ::tags {}
 set ::valgrind_errors {}
diff --git a/tests/tcl/tests/support/test.tcl b/tests/tcl/tests/support/test.tcl
index 39aebe1..736ef80 100644
--- a/tests/tcl/tests/support/test.tcl
+++ b/tests/tcl/tests/support/test.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/test.tcl
+
 set ::num_tests 0
 set ::num_passed 0
 set ::num_failed 0
diff --git a/tests/tcl/tests/support/tmpfile.tcl b/tests/tcl/tests/support/tmpfile.tcl
index 809f587..5f520ff 100644
--- a/tests/tcl/tests/support/tmpfile.tcl
+++ b/tests/tcl/tests/support/tmpfile.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/tmpfile.tcl
+
 set ::tmpcounter 0
 set ::tmproot "./tests/tmp"
 file mkdir $::tmproot
diff --git a/tests/tcl/tests/support/util.tcl b/tests/tcl/tests/support/util.tcl
index 0b421ae..fecccf4 100644
--- a/tests/tcl/tests/support/util.tcl
+++ b/tests/tcl/tests/support/util.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/support/util.tcl
+
 proc randstring {min max {type binary}} {
     set len [expr {$min+int(rand()*($max-$min+1))}]
     set output {}
diff --git a/tests/tcl/tests/test_helper.tcl b/tests/tcl/tests/test_helper.tcl
index 5446775..37bd37a 100644
--- a/tests/tcl/tests/test_helper.tcl
+++ b/tests/tcl/tests/test_helper.tcl
@@ -1,6 +1,27 @@
-# Redis test suite. Copyright (C) 2009 Salvatore Sanfilippo antirez@gmail.com
-# This software is released under the BSD License. See the COPYING file for
-# more information.
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2009, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/test_helper.tcl
+
+# Redis test suite.
 
 package require Tcl 8.5
 
diff --git a/tests/tcl/tests/unit/acl.tcl b/tests/tcl/tests/unit/acl.tcl
index f5e3259..d0f9d75 100644
--- a/tests/tcl/tests/unit/acl.tcl
+++ b/tests/tcl/tests/unit/acl.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/acl.tcl
+
 start_server {tags {"acl"}} {
     test {Connections start with the default user} {
         r ACL WHOAMI
diff --git a/tests/tcl/tests/unit/auth.tcl b/tests/tcl/tests/unit/auth.tcl
index 97e84f0..2611cf1 100644
--- a/tests/tcl/tests/unit/auth.tcl
+++ b/tests/tcl/tests/unit/auth.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/auth.tcl
+
 start_server {tags {"auth"}} {
     test {AUTH fails if there is no password configured server side} {
         catch {r auth foo} err
diff --git a/tests/tcl/tests/unit/bitfield.tcl b/tests/tcl/tests/unit/bitfield.tcl
index 1f2f639..30ca0fb 100644
--- a/tests/tcl/tests/unit/bitfield.tcl
+++ b/tests/tcl/tests/unit/bitfield.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/bitfield.tcl
+
 start_server {tags {"bitops"}} {
     test {BITFIELD signed SET and GET basics} {
         r del bits
diff --git a/tests/tcl/tests/unit/bitops.tcl b/tests/tcl/tests/unit/bitops.tcl
index f527aae..213e5b5 100644
--- a/tests/tcl/tests/unit/bitops.tcl
+++ b/tests/tcl/tests/unit/bitops.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/bitops.tcl
+
 # Compare Redis commands against Tcl implementations of the same commands.
 proc count_bits s {
     binary scan $s b* bits
diff --git a/tests/tcl/tests/unit/command.tcl b/tests/tcl/tests/unit/command.tcl
index dd176f1..11e9354 100644
--- a/tests/tcl/tests/unit/command.tcl
+++ b/tests/tcl/tests/unit/command.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 start_server {tags {"command"}} {
     test {kvrocks has 168 commands currently} {
         r command count
diff --git a/tests/tcl/tests/unit/config.tcl b/tests/tcl/tests/unit/config.tcl
index 85a8edc..940d76d 100644
--- a/tests/tcl/tests/unit/config.tcl
+++ b/tests/tcl/tests/unit/config.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 start_server {tags {"config"} overrides {rename-command "KEYS KEYSNEW"}} {
     test {Rename one command} {
         catch {r KEYS *} e
@@ -5,5 +22,3 @@ start_server {tags {"config"} overrides {rename-command "KEYS KEYSNEW"}} {
         assert_equal "" [r KEYSNEW *]
     }
 }
-
-
diff --git a/tests/tcl/tests/unit/expire.tcl b/tests/tcl/tests/unit/expire.tcl
index 3064001..88d884f 100644
--- a/tests/tcl/tests/unit/expire.tcl
+++ b/tests/tcl/tests/unit/expire.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/expire.tcl
+
 start_server {tags {"expire"}} {
     test {EXPIRE - set timeouts multiple times} {
         r set x foobar
diff --git a/tests/tcl/tests/unit/geo.tcl b/tests/tcl/tests/unit/geo.tcl
index 55a1640..8f0dde1 100644
--- a/tests/tcl/tests/unit/geo.tcl
+++ b/tests/tcl/tests/unit/geo.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/geo.tcl
+
 # Helper functions to simulate search-in-radius in the Tcl side in order to
 # verify the Redis implementation with a fuzzy test.
 proc geo_degrad deg {expr {$deg*atan(1)*8/360}}
diff --git a/tests/tcl/tests/unit/hyperloglog.tcl b/tests/tcl/tests/unit/hyperloglog.tcl
index db26a2e..7a7aae8 100644
--- a/tests/tcl/tests/unit/hyperloglog.tcl
+++ b/tests/tcl/tests/unit/hyperloglog.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/hyperloglog.tcl
+
 start_server {tags {"hll"}} {
     test {HyperLogLog self test passes} {
         catch {r pfselftest} e
diff --git a/tests/tcl/tests/unit/introspection.tcl b/tests/tcl/tests/unit/introspection.tcl
index 433a00a..420de74 100644
--- a/tests/tcl/tests/unit/introspection.tcl
+++ b/tests/tcl/tests/unit/introspection.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/introspection.tcl
+
 start_server {tags {"introspection"}} {
     test {CLIENT LIST} {
         r client list
diff --git a/tests/tcl/tests/unit/keyspace.tcl b/tests/tcl/tests/unit/keyspace.tcl
index eb10c3b..079afe3 100644
--- a/tests/tcl/tests/unit/keyspace.tcl
+++ b/tests/tcl/tests/unit/keyspace.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/keyspace.tcl
+
 start_server {tags {"keyspace"}} {
     test {DEL against a single item} {
         r set x foo
diff --git a/tests/tcl/tests/unit/limits.tcl b/tests/tcl/tests/unit/limits.tcl
index 51122e8..ce15e9c 100644
--- a/tests/tcl/tests/unit/limits.tcl
+++ b/tests/tcl/tests/unit/limits.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/limits.tcl
+
 start_server {tags {"limits network"} overrides {maxclients 10}} {
     if {$::tls} {
         set expected_code "*I/O error*"
diff --git a/tests/tcl/tests/unit/multi.tcl b/tests/tcl/tests/unit/multi.tcl
index dca76ce..769084a 100644
--- a/tests/tcl/tests/unit/multi.tcl
+++ b/tests/tcl/tests/unit/multi.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/multi.tcl
+
 start_server {tags {"multi"}} {
     test {MUTLI / EXEC basics} {
         r del mylist
diff --git a/tests/tcl/tests/unit/protocol.tcl b/tests/tcl/tests/unit/protocol.tcl
index f14c1df..a542741 100644
--- a/tests/tcl/tests/unit/protocol.tcl
+++ b/tests/tcl/tests/unit/protocol.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/protocol.tcl
+
 start_server {tags {"protocol network"}} {
     test "Handle an empty query" {
         reconnect
diff --git a/tests/tcl/tests/unit/pubsub.tcl b/tests/tcl/tests/unit/pubsub.tcl
index 918cf31..ce9da7f 100644
--- a/tests/tcl/tests/unit/pubsub.tcl
+++ b/tests/tcl/tests/unit/pubsub.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/pubsub.tcl
+
 start_server {tags {"pubsub"}} {
     proc __consume_subscribe_messages {client type channels} {
         set numsub -1
diff --git a/tests/tcl/tests/unit/quit.tcl b/tests/tcl/tests/unit/quit.tcl
index 4cf440a..4bb6132 100644
--- a/tests/tcl/tests/unit/quit.tcl
+++ b/tests/tcl/tests/unit/quit.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/quit.tcl
+
 start_server {tags {"quit"}} {
     proc format_command {args} {
         set cmd "*[llength $args]\r\n"
diff --git a/tests/tcl/tests/unit/scan.tcl b/tests/tcl/tests/unit/scan.tcl
index cbf1092..7653ca7 100644
--- a/tests/tcl/tests/unit/scan.tcl
+++ b/tests/tcl/tests/unit/scan.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/scan.tcl
+
 start_server {tags {"scan network"}} {
     test "SCAN basic" {
         r flushdb
diff --git a/tests/tcl/tests/unit/scripting.tcl b/tests/tcl/tests/unit/scripting.tcl
index f13de7f..d3fc47b 100644
--- a/tests/tcl/tests/unit/scripting.tcl
+++ b/tests/tcl/tests/unit/scripting.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/scripting.tcl
+
 start_server {tags {"scripting"}} {
     test {EVAL - Does Lua interpreter replies to our requests?} {
         r eval {return 'hello'} 0
diff --git a/tests/tcl/tests/unit/slowlog.tcl b/tests/tcl/tests/unit/slowlog.tcl
index 9a6737c..333791b 100644
--- a/tests/tcl/tests/unit/slowlog.tcl
+++ b/tests/tcl/tests/unit/slowlog.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/slowlog.tcl
+
 start_server {tags {"slowlog"} overrides {slowlog-log-slower-than 1000000}} {
     test {SLOWLOG - check that it starts with an empty log} {
         r slowlog len
diff --git a/tests/tcl/tests/unit/tls.tcl b/tests/tcl/tests/unit/tls.tcl
index a6c2f3c..75138d6 100644
--- a/tests/tcl/tests/unit/tls.tcl
+++ b/tests/tcl/tests/unit/tls.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/tls.tcl
+
 start_server {tags {"tls"}} {
     if {$::tls} {
         package require tls
diff --git a/tests/tcl/tests/unit/type/bitmap.tcl b/tests/tcl/tests/unit/type/bitmap.tcl
index 0cd3306..4a73748 100644
--- a/tests/tcl/tests/unit/type/bitmap.tcl
+++ b/tests/tcl/tests/unit/type/bitmap.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 proc simulate_bit_op {op args} {
     set maxlen 0
     set j 0
diff --git a/tests/tcl/tests/unit/type/hash.tcl b/tests/tcl/tests/unit/type/hash.tcl
index c394173..e34ece1 100644
--- a/tests/tcl/tests/unit/type/hash.tcl
+++ b/tests/tcl/tests/unit/type/hash.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/hash.tcl
+
 start_server {tags {"hash"}} {
     test {HSET/HLEN - Small hash creation} {
         array set smallhash {}
diff --git a/tests/tcl/tests/unit/type/incr.tcl b/tests/tcl/tests/unit/type/incr.tcl
index d875559..e551f33 100644
--- a/tests/tcl/tests/unit/type/incr.tcl
+++ b/tests/tcl/tests/unit/type/incr.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/incr.tcl
+
 start_server {tags {"incr"}} {
     test {INCR against non existing key} {
         set res {}
diff --git a/tests/tcl/tests/unit/type/list-2.tcl b/tests/tcl/tests/unit/type/list-2.tcl
index 4c7d6d9..493d5da 100644
--- a/tests/tcl/tests/unit/type/list-2.tcl
+++ b/tests/tcl/tests/unit/type/list-2.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/list-2.tcl
+
 start_server {
     tags {"list"}
     overrides {
diff --git a/tests/tcl/tests/unit/type/list-3.tcl b/tests/tcl/tests/unit/type/list-3.tcl
index b5bd48c..0cea10c 100644
--- a/tests/tcl/tests/unit/type/list-3.tcl
+++ b/tests/tcl/tests/unit/type/list-3.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/list-3.tcl
+
 start_server {
     tags {list ziplist}
     overrides {
diff --git a/tests/tcl/tests/unit/type/list-common.tcl b/tests/tcl/tests/unit/type/list-common.tcl
index ab45f0b..c012ddd 100644
--- a/tests/tcl/tests/unit/type/list-common.tcl
+++ b/tests/tcl/tests/unit/type/list-common.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/list-common.tcl
+
 # We need a value larger than list-max-ziplist-value to make sure
 # the list has the right encoding when it is swapped in again.
 array set largevalue {}
diff --git a/tests/tcl/tests/unit/type/list.tcl b/tests/tcl/tests/unit/type/list.tcl
index acc3578..9ec0f62 100644
--- a/tests/tcl/tests/unit/type/list.tcl
+++ b/tests/tcl/tests/unit/type/list.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/list.tcl
+
 start_server {
     tags {"list"}
 } {
diff --git a/tests/tcl/tests/unit/type/set.tcl b/tests/tcl/tests/unit/type/set.tcl
index 80b6f21..3608961 100644
--- a/tests/tcl/tests/unit/type/set.tcl
+++ b/tests/tcl/tests/unit/type/set.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/set.tcl
+
 start_server {
     tags {"set"}
 } {
diff --git a/tests/tcl/tests/unit/type/sint.tcl b/tests/tcl/tests/unit/type/sint.tcl
index 706d6ab..ad72873 100644
--- a/tests/tcl/tests/unit/type/sint.tcl
+++ b/tests/tcl/tests/unit/type/sint.tcl
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 start_server {tags {"sorted-int"}} {
     test {basic function of sint} {
         assert_equal 1 [r SIADD mysi 1]
diff --git a/tests/tcl/tests/unit/type/string.tcl b/tests/tcl/tests/unit/type/string.tcl
index 2e7f2a4..0d2aa08 100644
--- a/tests/tcl/tests/unit/type/string.tcl
+++ b/tests/tcl/tests/unit/type/string.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/string.tcl
+
 start_server {tags {"string"}} {
     test {SET and GET an item} {
         r set x foobar
diff --git a/tests/tcl/tests/unit/type/zset.tcl b/tests/tcl/tests/unit/type/zset.tcl
index cc48682..7c0ddb8 100644
--- a/tests/tcl/tests/unit/type/zset.tcl
+++ b/tests/tcl/tests/unit/type/zset.tcl
@@ -1,3 +1,26 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Copyright (c) 2006-2020, Salvatore Sanfilippo
+# See bundled license file licenses/LICENSE.redis for details.
+
+# This file is copied and modified from the Redis project,
+# which started out as: https://github.com/redis/redis/blob/dbcc0a8/tests/unit/type/zset.tcl
+
 start_server {tags {"zset"}} {
     proc create_zset {key items} {
         r del $key
diff --git a/tools/ci/licenserc.yml b/tools/ci/licenserc.yml
index c3f257f..ccf4bb1 100644
--- a/tools/ci/licenserc.yml
+++ b/tools/ci/licenserc.yml
@@ -27,6 +27,7 @@ header:
     - '**/*.h'
     - '**/*.py'
     - '**/*.sh'
+    - '**/*.tcl'
     - '**/*.yml'
     - '**/*.yaml'
   paths-ignore: