From 9a8e49f9edd5559e3fa41201e518ad6decccf838 Mon Sep 17 00:00:00 2001 From: Alexander Gallego Date: Wed, 11 Nov 2020 23:20:02 -0800 Subject: [PATCH 1/4] licenses: add bsl header to licenses --- licenses/bsl_header.txt | 8 ++++++++ 1 file changed, 8 insertions(+) create mode 100644 licenses/bsl_header.txt diff --git a/licenses/bsl_header.txt b/licenses/bsl_header.txt new file mode 100644 index 0000000000000..fe1306727d2a2 --- /dev/null +++ b/licenses/bsl_header.txt @@ -0,0 +1,8 @@ +Copyright 2020 Vectorized, Inc. + +Use of this software is governed by the Business Source License +included in the file licenses/BSL.md + +As of the Change Date specified in that file, in accordance with +the Business Source License, use of this software will be governed +by the Apache License, Version 2.0 From 6b13ca1778f66cc7c09bd252becfd68f5483f4cd Mon Sep 17 00:00:00 2001 From: Alexander Gallego Date: Wed, 11 Nov 2020 23:25:25 -0800 Subject: [PATCH 2/4] bsl: add bsl header to all bsl files --- .dir-locals.el | 9 +++++++++ .github/workflows/redpanda-build.yml | 9 +++++++++ .github/workflows/rpk-build.yml | 9 +++++++++ build.sh | 9 +++++++++ conf/pandaproxy.yaml | 9 +++++++++ conf/redpanda.yaml | 9 +++++++++ install-dependencies.sh | 9 +++++++++ .../chaostest/chaostest/__init__.py | 9 +++++++++ src/consistency-testing/chaostest/chaostest/faults.py | 9 +++++++++ .../chaostest/chaostest/kafka_cluster.py | 9 +++++++++ .../chaostest/chaostest/kvell_cluster.py | 9 +++++++++ .../chaostest/chaostest/redpanda_cluster.py | 9 +++++++++ .../chaostest/control/kafka/continue-service.sh | 9 +++++++++ .../chaostest/control/kafka/iofault.delay.sh | 9 +++++++++ .../chaostest/control/kafka/iofault.mount.sh | 9 +++++++++ .../chaostest/control/kafka/iofault.recover.sh | 9 +++++++++ .../chaostest/control/kafka/iofault.ruin.sh | 9 +++++++++ .../chaostest/control/kafka/iofault.umount.sh | 9 +++++++++ .../chaostest/control/kafka/is-service-running.sh | 9 +++++++++ .../chaostest/control/kafka/isolate-bi.sh | 9 +++++++++ .../chaostest/control/kafka/kill-api.sh | 9 +++++++++ .../chaostest/control/kafka/kill-kafka.sh | 9 +++++++++ .../chaostest/control/kafka/kill-zookeeper.sh | 9 +++++++++ .../chaostest/control/kafka/pause-service.sh | 9 +++++++++ .../chaostest/control/kafka/prep-dirs.sh | 9 +++++++++ .../chaostest/control/kafka/rejoin-bi.sh | 9 +++++++++ .../chaostest/control/kafka/strobe.inject.sh | 9 +++++++++ .../chaostest/control/kafka/strobe.kill.sh | 9 +++++++++ .../chaostest/control/kafka/strobe.recover.sh | 9 +++++++++ .../chaostest/control/kafka/wipe-out.sh | 9 +++++++++ src/consistency-testing/chaostest/control/kafkakv.py | 9 +++++++++ .../chaostest/control/kvelldb/continue-kvelldb.sh | 9 +++++++++ .../chaostest/control/kvelldb/iofault.delay.sh | 9 +++++++++ .../chaostest/control/kvelldb/iofault.mount.sh | 9 +++++++++ .../chaostest/control/kvelldb/iofault.recover.sh | 9 +++++++++ .../chaostest/control/kvelldb/iofault.ruin.sh | 9 +++++++++ .../chaostest/control/kvelldb/iofault.umount.sh | 9 +++++++++ .../chaostest/control/kvelldb/is-kvelldb-running.sh | 9 +++++++++ .../chaostest/control/kvelldb/isolate-bi.sh | 9 +++++++++ .../chaostest/control/kvelldb/kill-kvelldb.sh | 9 +++++++++ .../chaostest/control/kvelldb/pause-kvelldb.sh | 9 +++++++++ .../chaostest/control/kvelldb/rejoin-bi.sh | 9 +++++++++ .../chaostest/control/kvelldb/replica.sh | 9 +++++++++ .../chaostest/control/kvelldb/strobe.inject.sh | 9 +++++++++ .../chaostest/control/kvelldb/strobe.kill.sh | 9 +++++++++ .../chaostest/control/kvelldb/strobe.recover.sh | 9 +++++++++ .../chaostest/control/kvelldb/wipe-out.sh | 9 +++++++++ .../chaostest/control/redpanda/continue-service.sh | 9 +++++++++ .../chaostest/control/redpanda/create-topic.sh | 9 +++++++++ .../chaostest/control/redpanda/iofault.delay.sh | 9 +++++++++ .../chaostest/control/redpanda/iofault.mount.sh | 9 +++++++++ .../chaostest/control/redpanda/iofault.recover.sh | 9 +++++++++ .../chaostest/control/redpanda/iofault.ruin.sh | 9 +++++++++ .../chaostest/control/redpanda/iofault.umount.sh | 9 +++++++++ .../chaostest/control/redpanda/is-service-running.sh | 9 +++++++++ .../chaostest/control/redpanda/isolate-bi.sh | 9 +++++++++ .../chaostest/control/redpanda/kill-api.sh | 9 +++++++++ .../chaostest/control/redpanda/kill-service.sh | 9 +++++++++ .../chaostest/control/redpanda/pause-service.sh | 9 +++++++++ .../chaostest/control/redpanda/rejoin-bi.sh | 9 +++++++++ .../chaostest/control/redpanda/start-service.sh | 9 +++++++++ .../chaostest/control/redpanda/strobe.inject.sh | 9 +++++++++ .../chaostest/control/redpanda/strobe.kill.sh | 9 +++++++++ .../chaostest/control/redpanda/strobe.recover.sh | 9 +++++++++ .../chaostest/control/redpanda/wipe-out.sh | 9 +++++++++ src/consistency-testing/chaostest/control/strobe.py | 9 +++++++++ src/consistency-testing/chaostest/test-kafka.py | 9 +++++++++ src/consistency-testing/chaostest/test-kvelldb.py | 9 +++++++++ src/consistency-testing/chaostest/test-redpanda.py | 9 +++++++++ src/consistency-testing/gobekli/gobekli/__init__.py | 9 +++++++++ .../gobekli/gobekli/chaos/__init__.py | 9 +++++++++ .../gobekli/gobekli/chaos/analysis.py | 9 +++++++++ src/consistency-testing/gobekli/gobekli/chaos/main.py | 9 +++++++++ src/consistency-testing/gobekli/gobekli/consensus.py | 9 +++++++++ src/consistency-testing/gobekli/gobekli/kvapi.py | 9 +++++++++ src/consistency-testing/gobekli/gobekli/logging.py | 9 +++++++++ .../gobekli/gobekli/workloads/__init__.py | 9 +++++++++ .../gobekli/gobekli/workloads/common.py | 9 +++++++++ .../gobekli/gobekli/workloads/symmetrical_comrmw.py | 9 +++++++++ .../gobekli/gobekli/workloads/symmetrical_mrsw.py | 9 +++++++++ src/consistency-testing/gobekli/setup.py | 9 +++++++++ src/consistency-testing/gobekli/tests/__init__.py | 9 +++++++++ src/consistency-testing/gobekli/tests/consensus.py | 9 +++++++++ src/consistency-testing/iofaults/iofaults.py | 9 +++++++++ .../kafka-availability/availability_logger.py | 9 +++++++++ src/go/rpk/pkg/api/api.go | 9 +++++++++ src/go/rpk/pkg/api/api_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/consume.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/consume_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/produce.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/produce_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/status.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/status_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/topic.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/topic_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/api/utils.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/check.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/config.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/config_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/common/client.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/common/common.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/common/test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/purge.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/purge_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/start.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/start_darwin.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/start_linux.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/start_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/stop.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/container/stop_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go | 9 +++++++++ .../rpk/pkg/cli/cmd/generate/graf/dashboard_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/graph.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/row.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go | 9 +++++++++ .../rpk/pkg/cli/cmd/generate/graf/singlestat_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/graf/text.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/grafana.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/grafana_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/generate/prometheus.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/iotune.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/iotune_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/mode.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/mode_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/root.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/root_darwin.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/root_linux.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/start.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/start_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/status.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/status_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/stop.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/stop_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/tune.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/tune/help.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/tune_test.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/version.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/version/version.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm/generate.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go | 9 +++++++++ .../rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go | 9 +++++++++ src/go/rpk/pkg/cli/cmd/wasm_test.go | 9 +++++++++ src/go/rpk/pkg/cli/flags.go | 9 +++++++++ src/go/rpk/pkg/cli/log_formatter.go | 9 +++++++++ src/go/rpk/pkg/cli/ui/tables.go | 9 +++++++++ src/go/rpk/pkg/cloud/aws/aws.go | 9 +++++++++ src/go/rpk/pkg/cloud/gcp/gcp.go | 9 +++++++++ src/go/rpk/pkg/cloud/vendor/vendor.go | 9 +++++++++ src/go/rpk/pkg/cloud/vendors.go | 9 +++++++++ src/go/rpk/pkg/cloud/vendors_test.go | 9 +++++++++ src/go/rpk/pkg/cmd/groupcsaw/main.go | 9 +++++++++ src/go/rpk/pkg/cmd/kverify/main.go | 9 +++++++++ src/go/rpk/pkg/cmd/kverify/stats.go | 9 +++++++++ src/go/rpk/pkg/cmd/rpk/main.go | 9 +++++++++ src/go/rpk/pkg/config/config.go | 9 +++++++++ src/go/rpk/pkg/config/config_test.go | 9 +++++++++ src/go/rpk/pkg/config/find.go | 9 +++++++++ src/go/rpk/pkg/config/find_test.go | 9 +++++++++ src/go/rpk/pkg/config/license.go | 9 +++++++++ src/go/rpk/pkg/config/license_test.go | 9 +++++++++ src/go/rpk/pkg/kafka/client.go | 9 +++++++++ src/go/rpk/pkg/net/interfaces.go | 9 +++++++++ src/go/rpk/pkg/os/commands.go | 9 +++++++++ src/go/rpk/pkg/os/lock.go | 9 +++++++++ src/go/rpk/pkg/os/proc.go | 9 +++++++++ src/go/rpk/pkg/os/proc_test.go | 9 +++++++++ src/go/rpk/pkg/redpanda/launcher.go | 9 +++++++++ src/go/rpk/pkg/redpanda/launcher_test.go | 9 +++++++++ src/go/rpk/pkg/redpanda/paths.go | 9 +++++++++ src/go/rpk/pkg/system/cgroup.go | 9 +++++++++ src/go/rpk/pkg/system/cgroup_test.go | 9 +++++++++ src/go/rpk/pkg/system/cpu.go | 9 +++++++++ src/go/rpk/pkg/system/filesystem/fs.go | 9 +++++++++ src/go/rpk/pkg/system/filesystem/fs_darwin.go | 9 +++++++++ src/go/rpk/pkg/system/filesystem/fs_linux.go | 9 +++++++++ src/go/rpk/pkg/system/filesystem/fs_test.go | 9 +++++++++ src/go/rpk/pkg/system/filesystem/types.go | 9 +++++++++ src/go/rpk/pkg/system/grub.go | 9 +++++++++ src/go/rpk/pkg/system/grub_test.go | 9 +++++++++ src/go/rpk/pkg/system/memory.go | 9 +++++++++ src/go/rpk/pkg/system/memory_darwin.go | 9 +++++++++ src/go/rpk/pkg/system/memory_linux.go | 9 +++++++++ src/go/rpk/pkg/system/metrics.go | 9 +++++++++ src/go/rpk/pkg/system/ntp.go | 9 +++++++++ src/go/rpk/pkg/system/ntp_test.go | 9 +++++++++ src/go/rpk/pkg/system/runtime_options.go | 9 +++++++++ src/go/rpk/pkg/system/runtime_options_test.go | 9 +++++++++ src/go/rpk/pkg/system/systemd/client.go | 9 +++++++++ src/go/rpk/pkg/system/systemd/dbus.go | 9 +++++++++ src/go/rpk/pkg/system/systemd/mock.go | 9 +++++++++ src/go/rpk/pkg/system/utils.go | 9 +++++++++ src/go/rpk/pkg/system/utils_darwin.go | 9 +++++++++ src/go/rpk/pkg/system/utils_linux.go | 9 +++++++++ src/go/rpk/pkg/tuners/aggregated_tunable.go | 9 +++++++++ src/go/rpk/pkg/tuners/aggregated_tunable_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/aio.go | 9 +++++++++ src/go/rpk/pkg/tuners/aio_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/check.go | 9 +++++++++ src/go/rpk/pkg/tuners/checked_tunable.go | 9 +++++++++ src/go/rpk/pkg/tuners/checked_tunable_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/checker.go | 9 +++++++++ src/go/rpk/pkg/tuners/clocksource.go | 9 +++++++++ src/go/rpk/pkg/tuners/coredump/tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/coredump/tuner_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/cpu/tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_device.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_device_darwin.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_device_linux.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_device_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_devices.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_devices_darwin.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_devices_linux.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/block_devices_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/scheduler_info.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk/scheduler_info_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_checkers.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_nomerges_tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_scheduler_tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/disk_tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/disks_irq_tuner.go | 9 +++++++++ src/go/rpk/pkg/tuners/disks_irq_tuner_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/equality_checker.go | 9 +++++++++ src/go/rpk/pkg/tuners/equality_checker_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/ethtool/ethtool.go | 9 +++++++++ .../rpk/pkg/tuners/executors/commands/backup_file.go | 9 +++++++++ src/go/rpk/pkg/tuners/executors/commands/command.go | 9 +++++++++ .../pkg/tuners/executors/commands/ethtool_change.go | 9 +++++++++ src/go/rpk/pkg/tuners/executors/commands/execute.go | 9 +++++++++ .../rpk/pkg/tuners/executors/commands/sysctl_set.go | 9 +++++++++ .../tuners/executors/commands/systemd_install_unit.go | 9 +++++++++ .../executors/commands/systemd_install_unit_test.go | 9 +++++++++ .../tuners/executors/commands/systemd_start_unit.go | 9 +++++++++ .../executors/commands/systemd_start_unit_test.go | 9 +++++++++ .../rpk/pkg/tuners/executors/commands/write_file.go | 9 +++++++++ .../pkg/tuners/executors/commands/write_file_lines.go | 9 +++++++++ .../pkg/tuners/executors/commands/write_file_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/executors/direct.go | 9 +++++++++ src/go/rpk/pkg/tuners/executors/executor.go | 9 +++++++++ src/go/rpk/pkg/tuners/executors/script_rendering.go | 9 +++++++++ src/go/rpk/pkg/tuners/factory/factory.go | 9 +++++++++ src/go/rpk/pkg/tuners/factory/factory_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/file_existance_checker.go | 9 +++++++++ src/go/rpk/pkg/tuners/float_checker.go | 9 +++++++++ src/go/rpk/pkg/tuners/float_checker_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/fstrim.go | 9 +++++++++ src/go/rpk/pkg/tuners/fstrim_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/hwloc/cpuset.go | 9 +++++++++ src/go/rpk/pkg/tuners/hwloc/cpuset_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/hwloc/hwloc.go | 9 +++++++++ src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go | 9 +++++++++ src/go/rpk/pkg/tuners/int_checker.go | 9 +++++++++ src/go/rpk/pkg/tuners/int_checker_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/iotune.go | 9 +++++++++ src/go/rpk/pkg/tuners/iotune/data.go | 9 +++++++++ src/go/rpk/pkg/tuners/iotune/data_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/iotune/io_tune.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/balance_service.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/balance_service_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/cpu_masks.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/cpu_masks_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/device_info.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/device_info_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/proc_file.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/proc_file_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/irq/utils.go | 9 +++++++++ src/go/rpk/pkg/tuners/kernel_version.go | 9 +++++++++ src/go/rpk/pkg/tuners/kernel_version_darwin.go | 9 +++++++++ src/go/rpk/pkg/tuners/kernel_version_linux.go | 9 +++++++++ src/go/rpk/pkg/tuners/kernel_version_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/net_checkers.go | 9 +++++++++ src/go/rpk/pkg/tuners/net_tuners.go | 9 +++++++++ src/go/rpk/pkg/tuners/net_tuners_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/network/const.go | 9 +++++++++ src/go/rpk/pkg/tuners/network/nic.go | 9 +++++++++ src/go/rpk/pkg/tuners/network/nic_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/network/nics.go | 9 +++++++++ src/go/rpk/pkg/tuners/redpanda_checkers.go | 9 +++++++++ src/go/rpk/pkg/tuners/redpanda_checkers_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/swappiness.go | 9 +++++++++ src/go/rpk/pkg/tuners/swappiness_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/thp.go | 9 +++++++++ src/go/rpk/pkg/tuners/thp_test.go | 9 +++++++++ src/go/rpk/pkg/tuners/tunable.go | 9 +++++++++ src/go/rpk/pkg/tuners/tune_result.go | 9 +++++++++ src/go/rpk/pkg/tuners/tune_result_test.go | 9 +++++++++ src/go/rpk/pkg/utils/chained_error.go | 9 +++++++++ src/go/rpk/pkg/utils/collect.go | 9 +++++++++ src/go/rpk/pkg/utils/files.go | 9 +++++++++ src/go/rpk/pkg/utils/files_test.go | 9 +++++++++ src/go/rpk/pkg/utils/os.go | 9 +++++++++ src/go/rpk/pkg/utils/strings.go | 9 +++++++++ src/go/rpk/pkg/utils/strings_test.go | 9 +++++++++ src/go/rpk/pkg/yaml/yaml.go | 9 +++++++++ src/v/bytes/bytes.cc | 9 +++++++++ src/v/bytes/bytes.h | 11 +++++++++++ src/v/bytes/details/io_allocation_size.h | 11 +++++++++++ src/v/bytes/details/io_byte_iterator.h | 11 +++++++++++ src/v/bytes/details/io_fragment.h | 11 +++++++++++ src/v/bytes/details/io_iterator_consumer.h | 11 +++++++++++ src/v/bytes/details/io_placeholder.h | 11 +++++++++++ src/v/bytes/details/out_of_range.h | 11 +++++++++++ src/v/bytes/iobuf.cc | 9 +++++++++ src/v/bytes/iobuf.h | 11 +++++++++++ src/v/bytes/iobuf_file.h | 11 +++++++++++ src/v/bytes/iobuf_ostreambuf.h | 11 +++++++++++ src/v/bytes/iobuf_parser.h | 11 +++++++++++ src/v/bytes/tests/iobuf_tests.cc | 9 +++++++++ src/v/bytes/tests/iobuf_utils_tests.cc | 9 +++++++++ src/v/bytes/tests/utils.h | 11 +++++++++++ src/v/bytes/utils.h | 11 +++++++++++ src/v/cluster/cluster_utils.cc | 9 +++++++++ src/v/cluster/cluster_utils.h | 11 +++++++++++ src/v/cluster/commands.h | 11 +++++++++++ src/v/cluster/controller.cc | 9 +++++++++ src/v/cluster/controller.h | 11 +++++++++++ src/v/cluster/controller_backend.cc | 9 +++++++++ src/v/cluster/controller_backend.h | 11 +++++++++++ src/v/cluster/controller_stm.h | 11 +++++++++++ src/v/cluster/errc.h | 11 +++++++++++ src/v/cluster/logger.cc | 9 +++++++++ src/v/cluster/logger.h | 11 +++++++++++ src/v/cluster/members_manager.cc | 9 +++++++++ src/v/cluster/members_manager.h | 11 +++++++++++ src/v/cluster/members_table.cc | 9 +++++++++ src/v/cluster/members_table.h | 11 +++++++++++ src/v/cluster/metadata_cache.cc | 9 +++++++++ src/v/cluster/metadata_cache.h | 11 +++++++++++ src/v/cluster/metadata_dissemination_handler.cc | 9 +++++++++ src/v/cluster/metadata_dissemination_handler.h | 11 +++++++++++ src/v/cluster/metadata_dissemination_service.cc | 9 +++++++++ src/v/cluster/metadata_dissemination_service.h | 11 +++++++++++ src/v/cluster/metadata_dissemination_types.h | 11 +++++++++++ src/v/cluster/metadata_dissemination_utils.cc | 9 +++++++++ src/v/cluster/metadata_dissemination_utils.h | 11 +++++++++++ src/v/cluster/namespace.h | 11 +++++++++++ src/v/cluster/notification_latch.cc | 9 +++++++++ src/v/cluster/notification_latch.h | 11 +++++++++++ src/v/cluster/ntp_callbacks.h | 11 +++++++++++ src/v/cluster/partition.cc | 9 +++++++++ src/v/cluster/partition.h | 11 +++++++++++ src/v/cluster/partition_allocator.cc | 9 +++++++++ src/v/cluster/partition_allocator.h | 11 +++++++++++ src/v/cluster/partition_leaders_table.cc | 9 +++++++++ src/v/cluster/partition_leaders_table.h | 11 +++++++++++ src/v/cluster/partition_manager.cc | 9 +++++++++ src/v/cluster/partition_manager.h | 11 +++++++++++ src/v/cluster/partition_probe.cc | 9 +++++++++ src/v/cluster/partition_probe.h | 11 +++++++++++ src/v/cluster/raft0_utils.h | 11 +++++++++++ src/v/cluster/service.cc | 9 +++++++++ src/v/cluster/service.h | 11 +++++++++++ src/v/cluster/shard_table.h | 11 +++++++++++ src/v/cluster/simple_batch_builder.h | 11 +++++++++++ src/v/cluster/tests/allocation_bench.cc | 9 +++++++++ src/v/cluster/tests/autocreate_test.cc | 9 +++++++++ src/v/cluster/tests/cluster_test_fixture.h | 11 +++++++++++ src/v/cluster/tests/cluster_tests.cc | 9 +++++++++ src/v/cluster/tests/cluster_utils_tests.cc | 9 +++++++++ src/v/cluster/tests/commands_serialization_test.cc | 9 +++++++++ src/v/cluster/tests/configuration_change_test.cc | 9 +++++++++ src/v/cluster/tests/controller_recovery_test.cc | 9 +++++++++ src/v/cluster/tests/controller_state_test.cc | 9 +++++++++ src/v/cluster/tests/controller_test_fixture.h | 11 +++++++++++ src/v/cluster/tests/metadata_dissemination_test.cc | 9 +++++++++ .../tests/metadata_dissemination_utils_test.cc | 9 +++++++++ src/v/cluster/tests/notification_latch_test.cc | 9 +++++++++ src/v/cluster/tests/partition_allocator_tester.h | 11 +++++++++++ src/v/cluster/tests/partition_allocator_tests.cc | 9 +++++++++ src/v/cluster/tests/partition_reassignment_test.cc | 9 +++++++++ src/v/cluster/tests/serialization_rt_test.cc | 9 +++++++++ src/v/cluster/tests/simple_batch_builder_test.cc | 9 +++++++++ src/v/cluster/tests/topic_table_fixture.h | 11 +++++++++++ src/v/cluster/tests/topic_table_test.cc | 9 +++++++++ src/v/cluster/tests/topic_updates_dispatcher_test.cc | 9 +++++++++ src/v/cluster/tests/utils.h | 11 +++++++++++ src/v/cluster/topic_table.cc | 9 +++++++++ src/v/cluster/topic_table.h | 11 +++++++++++ src/v/cluster/topic_updates_dispatcher.cc | 9 +++++++++ src/v/cluster/topic_updates_dispatcher.h | 11 +++++++++++ src/v/cluster/topics_frontend.cc | 9 +++++++++ src/v/cluster/topics_frontend.h | 11 +++++++++++ src/v/cluster/types.cc | 9 +++++++++ src/v/cluster/types.h | 11 +++++++++++ src/v/compression/compression.cc | 9 +++++++++ src/v/compression/compression.h | 11 +++++++++++ src/v/compression/internal/gzip_compressor.cc | 9 +++++++++ src/v/compression/internal/gzip_compressor.h | 11 +++++++++++ src/v/compression/internal/lz4_frame_compressor.cc | 9 +++++++++ src/v/compression/internal/lz4_frame_compressor.h | 11 +++++++++++ src/v/compression/internal/snappy_java_compressor.cc | 9 +++++++++ src/v/compression/internal/snappy_java_compressor.h | 11 +++++++++++ src/v/compression/internal/zstd_compressor.h | 11 +++++++++++ src/v/compression/logger.cc | 9 +++++++++ src/v/compression/logger.h | 11 +++++++++++ src/v/compression/snappy_standard_compressor.cc | 9 +++++++++ src/v/compression/snappy_standard_compressor.h | 11 +++++++++++ src/v/compression/stream_zstd.cc | 9 +++++++++ src/v/compression/stream_zstd.h | 11 +++++++++++ src/v/compression/tests/zstd_stream_bench.cc | 9 +++++++++ src/v/compression/tests/zstd_tests.cc | 9 +++++++++ src/v/config/base_property.cc | 9 +++++++++ src/v/config/base_property.h | 11 +++++++++++ src/v/config/config_store.h | 11 +++++++++++ src/v/config/configuration.cc | 9 +++++++++ src/v/config/configuration.h | 11 +++++++++++ src/v/config/data_directory_path.h | 11 +++++++++++ src/v/config/property.h | 11 +++++++++++ src/v/config/rjson_serialization.cc | 9 +++++++++ src/v/config/rjson_serialization.h | 11 +++++++++++ src/v/config/seed_server.h | 11 +++++++++++ src/v/config/tests/advertised_kafka_api_test.cc | 9 +++++++++ src/v/config/tests/config_store_test.cc | 9 +++++++++ src/v/config/tests/custom_aggregate.h | 11 +++++++++++ src/v/config/tests/socket_address_convert_test.cc | 9 +++++++++ src/v/config/tests/tls_config_convert_test.cc | 9 +++++++++ src/v/config/tls_config.h | 11 +++++++++++ src/v/config/validation_error.h | 11 +++++++++++ src/v/finjector/hbadger.cc | 9 +++++++++ src/v/finjector/hbadger.h | 11 +++++++++++ src/v/hashing/crc32c.h | 11 +++++++++++ src/v/hashing/fnv.h | 11 +++++++++++ src/v/hashing/hash_bench.cc | 9 +++++++++ src/v/hashing/jenkins.h | 11 +++++++++++ src/v/hashing/jump_consistent_hash.h | 11 +++++++++++ src/v/hashing/murmur.cc | 9 +++++++++ src/v/hashing/murmur.h | 11 +++++++++++ src/v/hashing/twang.h | 11 +++++++++++ src/v/hashing/xx.h | 11 +++++++++++ src/v/hashing/xx_tests.cc | 9 +++++++++ src/v/http/chunk_encoding.cc | 9 +++++++++ src/v/http/chunk_encoding.h | 11 +++++++++++ src/v/http/client.cc | 9 +++++++++ src/v/http/client.h | 11 +++++++++++ src/v/http/demo/client.cc | 9 +++++++++ src/v/http/demo/echo.py | 9 +++++++++ src/v/http/demo/run.sh | 9 +++++++++ src/v/http/iobuf_body.cc | 9 +++++++++ src/v/http/iobuf_body.h | 11 +++++++++++ src/v/http/logger.cc | 9 +++++++++ src/v/http/logger.h | 11 +++++++++++ src/v/http/tests/framing_test.cc | 9 +++++++++ src/v/http/tests/http_client_test.cc | 9 +++++++++ src/v/json/json.cc | 9 +++++++++ src/v/json/json.h | 11 +++++++++++ src/v/json/tests/json_serialization_test.cc | 9 +++++++++ src/v/kafka/client.h | 11 +++++++++++ src/v/kafka/errors.cc | 9 +++++++++ src/v/kafka/errors.h | 11 +++++++++++ src/v/kafka/groups/coordinator_ntp_mapper.h | 11 +++++++++++ src/v/kafka/groups/group.cc | 9 +++++++++ src/v/kafka/groups/group.h | 11 +++++++++++ src/v/kafka/groups/group_manager.cc | 9 +++++++++ src/v/kafka/groups/group_manager.h | 11 +++++++++++ src/v/kafka/groups/group_router.h | 11 +++++++++++ src/v/kafka/groups/member.cc | 9 +++++++++ src/v/kafka/groups/member.h | 11 +++++++++++ src/v/kafka/logger.cc | 9 +++++++++ src/v/kafka/logger.h | 11 +++++++++++ src/v/kafka/protocol.cc | 9 +++++++++ src/v/kafka/protocol.h | 11 +++++++++++ src/v/kafka/protocol_utils.cc | 9 +++++++++ src/v/kafka/protocol_utils.h | 11 +++++++++++ src/v/kafka/quota_manager.cc | 9 +++++++++ src/v/kafka/quota_manager.h | 11 +++++++++++ src/v/kafka/requests/alter_configs_request.cc | 9 +++++++++ src/v/kafka/requests/alter_configs_request.h | 11 +++++++++++ src/v/kafka/requests/api_versions_request.cc | 9 +++++++++ src/v/kafka/requests/api_versions_request.h | 11 +++++++++++ src/v/kafka/requests/batch_consumer.h | 11 +++++++++++ src/v/kafka/requests/create_topics_request.cc | 9 +++++++++ src/v/kafka/requests/create_topics_request.h | 11 +++++++++++ src/v/kafka/requests/delete_groups_request.h | 11 +++++++++++ src/v/kafka/requests/delete_topics_request.cc | 9 +++++++++ src/v/kafka/requests/delete_topics_request.h | 11 +++++++++++ src/v/kafka/requests/describe_configs_request.cc | 9 +++++++++ src/v/kafka/requests/describe_configs_request.h | 11 +++++++++++ src/v/kafka/requests/describe_groups_request.cc | 9 +++++++++ src/v/kafka/requests/describe_groups_request.h | 11 +++++++++++ src/v/kafka/requests/fetch_request.cc | 9 +++++++++ src/v/kafka/requests/fetch_request.h | 11 +++++++++++ src/v/kafka/requests/find_coordinator_request.cc | 9 +++++++++ src/v/kafka/requests/find_coordinator_request.h | 11 +++++++++++ src/v/kafka/requests/fwd.h | 11 +++++++++++ src/v/kafka/requests/heartbeat_request.cc | 9 +++++++++ src/v/kafka/requests/heartbeat_request.h | 11 +++++++++++ src/v/kafka/requests/join_group_request.cc | 9 +++++++++ src/v/kafka/requests/join_group_request.h | 11 +++++++++++ src/v/kafka/requests/kafka_batch_adapter.cc | 9 +++++++++ src/v/kafka/requests/kafka_batch_adapter.h | 11 +++++++++++ src/v/kafka/requests/leave_group_request.cc | 9 +++++++++ src/v/kafka/requests/leave_group_request.h | 11 +++++++++++ src/v/kafka/requests/list_groups_request.cc | 9 +++++++++ src/v/kafka/requests/list_groups_request.h | 11 +++++++++++ src/v/kafka/requests/list_offsets_request.cc | 9 +++++++++ src/v/kafka/requests/list_offsets_request.h | 11 +++++++++++ src/v/kafka/requests/metadata_request.cc | 9 +++++++++ src/v/kafka/requests/metadata_request.h | 11 +++++++++++ src/v/kafka/requests/offset_commit_request.cc | 9 +++++++++ src/v/kafka/requests/offset_commit_request.h | 11 +++++++++++ src/v/kafka/requests/offset_fetch_request.cc | 9 +++++++++ src/v/kafka/requests/offset_fetch_request.h | 11 +++++++++++ src/v/kafka/requests/produce_request.cc | 9 +++++++++ src/v/kafka/requests/produce_request.h | 11 +++++++++++ src/v/kafka/requests/request_context.h | 11 +++++++++++ src/v/kafka/requests/request_reader.h | 11 +++++++++++ src/v/kafka/requests/requests.cc | 9 +++++++++ src/v/kafka/requests/requests.h | 11 +++++++++++ src/v/kafka/requests/response.h | 11 +++++++++++ src/v/kafka/requests/response_writer.h | 11 +++++++++++ src/v/kafka/requests/response_writer_utils.h | 11 +++++++++++ src/v/kafka/requests/schemata/generator.py | 9 +++++++++ src/v/kafka/requests/sync_group_request.cc | 9 +++++++++ src/v/kafka/requests/sync_group_request.h | 11 +++++++++++ src/v/kafka/requests/timeout.h | 11 +++++++++++ src/v/kafka/requests/topics/topic_utils.cc | 9 +++++++++ src/v/kafka/requests/topics/topic_utils.h | 11 +++++++++++ src/v/kafka/requests/topics/types.cc | 9 +++++++++ src/v/kafka/requests/topics/types.h | 11 +++++++++++ src/v/kafka/requests/topics/validators.h | 11 +++++++++++ src/v/kafka/tests/api_versions_test.cc | 9 +++++++++ src/v/kafka/tests/create_topics_test.cc | 9 +++++++++ src/v/kafka/tests/delete_topics_test.cc | 9 +++++++++ src/v/kafka/tests/error_mapping_test.cc | 9 +++++++++ src/v/kafka/tests/fetch_test.cc | 9 +++++++++ src/v/kafka/tests/find_coordinator_test.cc | 9 +++++++++ src/v/kafka/tests/group_test.cc | 9 +++++++++ src/v/kafka/tests/list_offsets_test.cc | 9 +++++++++ src/v/kafka/tests/member_test.cc | 9 +++++++++ src/v/kafka/tests/metadata_test.cc | 9 +++++++++ src/v/kafka/tests/offset_commit_test.cc | 9 +++++++++ src/v/kafka/tests/offset_fetch_test.cc | 9 +++++++++ src/v/kafka/tests/produce_consume_test.cc | 9 +++++++++ src/v/kafka/tests/read_write_roundtrip_test.cc | 9 +++++++++ src/v/kafka/tests/request_parser_test.cc | 9 +++++++++ src/v/kafka/tests/timeouts_conversion_test.cc | 9 +++++++++ src/v/kafka/tests/topic_recreate_test.cc | 9 +++++++++ src/v/kafka/tests/topic_utils_test.cc | 9 +++++++++ src/v/kafka/tests/types_conversion_tests.cc | 9 +++++++++ src/v/kafka/types.h | 11 +++++++++++ src/v/likely.h | 11 +++++++++++ src/v/model/adl_serde.cc | 9 +++++++++ src/v/model/adl_serde.h | 11 +++++++++++ src/v/model/async_adl_serde.cc | 9 +++++++++ src/v/model/async_adl_serde.h | 11 +++++++++++ src/v/model/compression.h | 11 +++++++++++ src/v/model/errc.h | 11 +++++++++++ src/v/model/fundamental.h | 11 +++++++++++ src/v/model/limits.h | 11 +++++++++++ src/v/model/metadata.h | 11 +++++++++++ src/v/model/model.cc | 9 +++++++++ src/v/model/record.h | 11 +++++++++++ src/v/model/record_batch_reader.cc | 9 +++++++++ src/v/model/record_batch_reader.h | 11 +++++++++++ src/v/model/record_batch_types.h | 11 +++++++++++ src/v/model/record_utils.cc | 9 +++++++++ src/v/model/record_utils.h | 11 +++++++++++ src/v/model/tests/compression_lexical_cast_test.cc | 9 +++++++++ src/v/model/tests/model_serialization_test.cc | 9 +++++++++ src/v/model/tests/ntp_path_test.cc | 9 +++++++++ src/v/model/tests/record_batch_reader_test.cc | 9 +++++++++ src/v/model/tests/record_batch_test.cc | 9 +++++++++ src/v/model/tests/topic_view_tests.cc | 9 +++++++++ src/v/model/timeout_clock.h | 11 +++++++++++ src/v/model/timestamp.h | 11 +++++++++++ src/v/model/validation.cc | 9 +++++++++ src/v/model/validation.h | 11 +++++++++++ src/v/oncore.h | 11 +++++++++++ src/v/outcome.h | 11 +++++++++++ src/v/outcome_future_utils.h | 11 +++++++++++ src/v/outcome_tests.cc | 9 +++++++++ src/v/pandaproxy/application.cc | 9 +++++++++ src/v/pandaproxy/application.h | 11 +++++++++++ src/v/pandaproxy/client/broker.cc | 9 +++++++++ src/v/pandaproxy/client/broker.h | 11 +++++++++++ src/v/pandaproxy/client/brokers.cc | 9 +++++++++ src/v/pandaproxy/client/brokers.h | 11 +++++++++++ src/v/pandaproxy/client/client.cc | 9 +++++++++ src/v/pandaproxy/client/client.h | 11 +++++++++++ src/v/pandaproxy/client/configuration.cc | 9 +++++++++ src/v/pandaproxy/client/configuration.h | 11 +++++++++++ src/v/pandaproxy/client/error.h | 11 +++++++++++ src/v/pandaproxy/client/logger.cc | 9 +++++++++ src/v/pandaproxy/client/logger.h | 11 +++++++++++ src/v/pandaproxy/client/produce_batcher.h | 11 +++++++++++ src/v/pandaproxy/client/produce_partition.h | 11 +++++++++++ src/v/pandaproxy/client/producer.cc | 9 +++++++++ src/v/pandaproxy/client/producer.h | 11 +++++++++++ src/v/pandaproxy/client/retry_with_mitigation.h | 11 +++++++++++ .../client/test/pandaproxy_client_fixture.h | 11 +++++++++++ src/v/pandaproxy/client/test/produce.cc | 9 +++++++++ src/v/pandaproxy/client/test/produce_batcher.cc | 9 +++++++++ src/v/pandaproxy/client/test/produce_partition.cc | 9 +++++++++ src/v/pandaproxy/client/test/reconnect.cc | 9 +++++++++ src/v/pandaproxy/client/test/retry_with_mitigation.cc | 9 +++++++++ src/v/pandaproxy/client/test/utils.h | 11 +++++++++++ src/v/pandaproxy/configuration.cc | 9 +++++++++ src/v/pandaproxy/configuration.h | 11 +++++++++++ src/v/pandaproxy/context.h | 11 +++++++++++ src/v/pandaproxy/handlers.cc | 9 +++++++++ src/v/pandaproxy/handlers.h | 11 +++++++++++ src/v/pandaproxy/json/iobuf.h | 11 +++++++++++ src/v/pandaproxy/json/requests/error_reply.h | 11 +++++++++++ src/v/pandaproxy/json/requests/produce.h | 11 +++++++++++ src/v/pandaproxy/json/requests/test/produce.cc | 9 +++++++++ src/v/pandaproxy/json/rjson_util.h | 11 +++++++++++ src/v/pandaproxy/json/test/iobuf.cc | 9 +++++++++ src/v/pandaproxy/json/types.h | 11 +++++++++++ src/v/pandaproxy/logger.cc | 9 +++++++++ src/v/pandaproxy/logger.h | 11 +++++++++++ src/v/pandaproxy/main.cc | 9 +++++++++ src/v/pandaproxy/probe.cc | 9 +++++++++ src/v/pandaproxy/probe.h | 11 +++++++++++ src/v/pandaproxy/proxy.cc | 9 +++++++++ src/v/pandaproxy/proxy.h | 11 +++++++++++ src/v/pandaproxy/reply.h | 11 +++++++++++ src/v/pandaproxy/server.cc | 9 +++++++++ src/v/pandaproxy/server.h | 11 +++++++++++ src/v/pandaproxy/test/list_topics.cc | 9 +++++++++ src/v/pandaproxy/test/pandaproxy_fixture.h | 11 +++++++++++ src/v/pandaproxy/test/produce.cc | 9 +++++++++ src/v/pandaproxy/test/utils.h | 11 +++++++++++ src/v/pandaproxy/types.h | 11 +++++++++++ src/v/platform/stop_signal.h | 11 +++++++++++ src/v/prometheus/prometheus_sanitize.h | 11 +++++++++++ src/v/raft/configuration.cc | 9 +++++++++ src/v/raft/configuration.h | 11 +++++++++++ src/v/raft/configuration_bootstrap_state.cc | 9 +++++++++ src/v/raft/configuration_bootstrap_state.h | 11 +++++++++++ src/v/raft/configuration_manager.cc | 9 +++++++++ src/v/raft/configuration_manager.h | 11 +++++++++++ src/v/raft/consensus.cc | 9 +++++++++ src/v/raft/consensus.h | 11 +++++++++++ src/v/raft/consensus_client_protocol.h | 11 +++++++++++ src/v/raft/consensus_utils.cc | 9 +++++++++ src/v/raft/consensus_utils.h | 11 +++++++++++ src/v/raft/errc.h | 11 +++++++++++ src/v/raft/event_manager.cc | 9 +++++++++ src/v/raft/event_manager.h | 11 +++++++++++ src/v/raft/follower_stats.cc | 9 +++++++++ src/v/raft/follower_stats.h | 11 +++++++++++ src/v/raft/group_manager.cc | 9 +++++++++ src/v/raft/group_manager.h | 11 +++++++++++ src/v/raft/heartbeat_manager.cc | 9 +++++++++ src/v/raft/heartbeat_manager.h | 11 +++++++++++ src/v/raft/kvelldb/errc.h | 11 +++++++++++ src/v/raft/kvelldb/httpkvrsm.cc | 9 +++++++++ src/v/raft/kvelldb/httpkvrsm.h | 11 +++++++++++ src/v/raft/kvelldb/kvrsm.cc | 9 +++++++++ src/v/raft/kvelldb/kvrsm.h | 11 +++++++++++ src/v/raft/kvelldb/kvserver.cc | 9 +++++++++ src/v/raft/kvelldb/logger.cc | 9 +++++++++ src/v/raft/kvelldb/logger.h | 11 +++++++++++ src/v/raft/log_eviction_stm.cc | 9 +++++++++ src/v/raft/log_eviction_stm.h | 11 +++++++++++ src/v/raft/logger.cc | 9 +++++++++ src/v/raft/logger.h | 11 +++++++++++ src/v/raft/mux_state_machine.h | 11 +++++++++++ src/v/raft/offset_monitor.cc | 9 +++++++++ src/v/raft/offset_monitor.h | 11 +++++++++++ src/v/raft/prevote_stm.cc | 9 +++++++++ src/v/raft/prevote_stm.h | 11 +++++++++++ src/v/raft/probe.cc | 9 +++++++++ src/v/raft/probe.h | 11 +++++++++++ src/v/raft/recovery_stm.cc | 9 +++++++++ src/v/raft/recovery_stm.h | 11 +++++++++++ src/v/raft/replicate_batcher.cc | 9 +++++++++ src/v/raft/replicate_batcher.h | 11 +++++++++++ src/v/raft/replicate_entries_stm.cc | 9 +++++++++ src/v/raft/replicate_entries_stm.h | 11 +++++++++++ src/v/raft/rpc_client_protocol.cc | 9 +++++++++ src/v/raft/rpc_client_protocol.h | 11 +++++++++++ src/v/raft/service.h | 11 +++++++++++ src/v/raft/state_machine.cc | 9 +++++++++ src/v/raft/state_machine.h | 11 +++++++++++ src/v/raft/tests/append_entries_test.cc | 9 +++++++++ src/v/raft/tests/bootstrap_configuration_test.cc | 9 +++++++++ src/v/raft/tests/configuration_manager_test.cc | 9 +++++++++ src/v/raft/tests/configuration_serialization_test.cc | 9 +++++++++ src/v/raft/tests/consensus_utils_test.cc | 9 +++++++++ src/v/raft/tests/foreign_entry_test.cc | 9 +++++++++ src/v/raft/tests/group_configuration_tests.cc | 9 +++++++++ src/v/raft/tests/jitter_tests.cc | 9 +++++++++ src/v/raft/tests/leadership_test.cc | 9 +++++++++ src/v/raft/tests/membership_test.cc | 9 +++++++++ src/v/raft/tests/mux_state_machine_fixture.h | 11 +++++++++++ src/v/raft/tests/mux_state_machine_test.cc | 9 +++++++++ src/v/raft/tests/offset_monitor_test.cc | 9 +++++++++ src/v/raft/tests/raft_group_fixture.h | 11 +++++++++++ src/v/raft/tests/simple_record_fixture.h | 11 +++++++++++ src/v/raft/tests/term_assigning_reader_test.cc | 9 +++++++++ src/v/raft/tests/type_serialization_tests.cc | 9 +++++++++ src/v/raft/timeout_jitter.h | 11 +++++++++++ src/v/raft/tron/client.cc | 9 +++++++++ src/v/raft/tron/logger.cc | 9 +++++++++ src/v/raft/tron/logger.h | 11 +++++++++++ src/v/raft/tron/server.cc | 9 +++++++++ src/v/raft/tron/service.h | 11 +++++++++++ src/v/raft/tron/types.h | 11 +++++++++++ src/v/raft/types.cc | 9 +++++++++ src/v/raft/types.h | 11 +++++++++++ src/v/raft/vote_stm.cc | 9 +++++++++ src/v/raft/vote_stm.h | 11 +++++++++++ src/v/random/fast_prng.h | 11 +++++++++++ src/v/random/generators.h | 11 +++++++++++ src/v/random/random_test.cc | 9 +++++++++ src/v/random/simple_time_jitter.h | 11 +++++++++++ src/v/redpanda/application.cc | 9 +++++++++ src/v/redpanda/application.h | 11 +++++++++++ src/v/redpanda/main.cc | 9 +++++++++ src/v/redpanda/tests/fixture.h | 11 +++++++++++ src/v/reflection/adl.h | 11 +++++++++++ src/v/reflection/arity.h | 11 +++++++++++ src/v/reflection/async_adl.h | 11 +++++++++++ src/v/reflection/for_each_field.h | 11 +++++++++++ src/v/reflection/test/arity_test.cc | 9 +++++++++ src/v/reflection/test/async_adl_test.cc | 9 +++++++++ src/v/reflection/to_tuple.h | 11 +++++++++++ src/v/resource_mgmt/cpu_scheduling.h | 11 +++++++++++ src/v/resource_mgmt/io_priority.h | 11 +++++++++++ src/v/resource_mgmt/memory_groups.h | 11 +++++++++++ src/v/resource_mgmt/rate.h | 11 +++++++++++ src/v/resource_mgmt/smp_groups.h | 11 +++++++++++ src/v/rpc/backoff_policy.h | 11 +++++++++++ src/v/rpc/batched_output_stream.cc | 9 +++++++++ src/v/rpc/batched_output_stream.h | 11 +++++++++++ src/v/rpc/client_probe.h | 11 +++++++++++ src/v/rpc/connection.cc | 9 +++++++++ src/v/rpc/connection.h | 11 +++++++++++ src/v/rpc/connection_cache.cc | 9 +++++++++ src/v/rpc/connection_cache.h | 11 +++++++++++ src/v/rpc/demo/client.cc | 9 +++++++++ src/v/rpc/demo/demo_utils.h | 11 +++++++++++ src/v/rpc/demo/server.cc | 9 +++++++++ src/v/rpc/demo/type_tests.cc | 9 +++++++++ src/v/rpc/demo/types.h | 11 +++++++++++ src/v/rpc/errc.h | 11 +++++++++++ src/v/rpc/exceptions.h | 11 +++++++++++ src/v/rpc/logger.cc | 9 +++++++++ src/v/rpc/logger.h | 11 +++++++++++ src/v/rpc/netbuf.cc | 9 +++++++++ src/v/rpc/netbuf.h | 11 +++++++++++ src/v/rpc/parse_utils.h | 11 +++++++++++ src/v/rpc/probes.cc | 9 +++++++++ src/v/rpc/reconnect_transport.cc | 9 +++++++++ src/v/rpc/reconnect_transport.h | 11 +++++++++++ src/v/rpc/response_handler.h | 11 +++++++++++ src/v/rpc/server.cc | 9 +++++++++ src/v/rpc/server.h | 11 +++++++++++ src/v/rpc/server_probe.h | 11 +++++++++++ src/v/rpc/service.h | 11 +++++++++++ src/v/rpc/simple_protocol.cc | 9 +++++++++ src/v/rpc/simple_protocol.h | 11 +++++++++++ src/v/rpc/test/exponential_backoff.cc | 9 +++++++++ src/v/rpc/test/netbuf_tests.cc | 9 +++++++++ src/v/rpc/test/response_handler_tests.cc | 9 +++++++++ src/v/rpc/test/roundtrip_tests.cc | 9 +++++++++ src/v/rpc/test/rpc_bench.cc | 9 +++++++++ src/v/rpc/test/rpc_gen_cycling_test.cc | 9 +++++++++ src/v/rpc/test/rpc_gen_types.h | 11 +++++++++++ src/v/rpc/test/rpc_integration_fixture.h | 11 +++++++++++ src/v/rpc/test/serialization_test.cc | 9 +++++++++ src/v/rpc/test/test_types.h | 11 +++++++++++ src/v/rpc/transport.cc | 9 +++++++++ src/v/rpc/transport.h | 11 +++++++++++ src/v/rpc/types.cc | 9 +++++++++ src/v/rpc/types.h | 11 +++++++++++ src/v/seastarx.h | 11 +++++++++++ src/v/ssx/future-util.h | 11 +++++++++++ src/v/ssx/tests/async_transforms.cc | 9 +++++++++ src/v/static_deleter_fn.h | 11 +++++++++++ src/v/storage/api.h | 11 +++++++++++ src/v/storage/batch_cache.cc | 9 +++++++++ src/v/storage/batch_cache.h | 11 +++++++++++ src/v/storage/compacted_index.h | 11 +++++++++++ src/v/storage/compacted_index_chunk_reader.cc | 9 +++++++++ src/v/storage/compacted_index_chunk_reader.h | 11 +++++++++++ src/v/storage/compacted_index_reader.h | 11 +++++++++++ src/v/storage/compacted_index_writer.h | 11 +++++++++++ src/v/storage/compacted_offset_list.h | 11 +++++++++++ src/v/storage/compaction_reducers.cc | 9 +++++++++ src/v/storage/compaction_reducers.h | 11 +++++++++++ src/v/storage/directories.h | 11 +++++++++++ src/v/storage/disk_log_appender.cc | 9 +++++++++ src/v/storage/disk_log_appender.h | 11 +++++++++++ src/v/storage/disk_log_impl.cc | 9 +++++++++ src/v/storage/disk_log_impl.h | 11 +++++++++++ src/v/storage/exceptions.h | 11 +++++++++++ src/v/storage/failure_probes.h | 11 +++++++++++ src/v/storage/fs_utils.h | 11 +++++++++++ src/v/storage/index_state.cc | 9 +++++++++ src/v/storage/index_state.h | 11 +++++++++++ src/v/storage/kvstore.cc | 9 +++++++++ src/v/storage/kvstore.h | 11 +++++++++++ src/v/storage/lock_manager.cc | 9 +++++++++ src/v/storage/lock_manager.h | 11 +++++++++++ src/v/storage/log.h | 11 +++++++++++ src/v/storage/log_appender.h | 11 +++++++++++ src/v/storage/log_housekeeping_meta.h | 11 +++++++++++ src/v/storage/log_manager.cc | 9 +++++++++ src/v/storage/log_manager.h | 11 +++++++++++ src/v/storage/log_reader.cc | 9 +++++++++ src/v/storage/log_reader.h | 11 +++++++++++ src/v/storage/log_replayer.cc | 9 +++++++++ src/v/storage/log_replayer.h | 11 +++++++++++ src/v/storage/logger.cc | 9 +++++++++ src/v/storage/logger.h | 11 +++++++++++ src/v/storage/mem_log_impl.cc | 9 +++++++++ src/v/storage/ntp_config.h | 11 +++++++++++ src/v/storage/offset_assignment.h | 11 +++++++++++ src/v/storage/offset_to_filepos_consumer.h | 11 +++++++++++ src/v/storage/opfuzz/opfuzz.cc | 9 +++++++++ src/v/storage/opfuzz/opfuzz.h | 11 +++++++++++ src/v/storage/opfuzz/opfuzz_test.cc | 9 +++++++++ src/v/storage/parser.cc | 9 +++++++++ src/v/storage/parser.h | 11 +++++++++++ src/v/storage/parser_errc.h | 11 +++++++++++ src/v/storage/parser_utils.cc | 9 +++++++++ src/v/storage/parser_utils.h | 11 +++++++++++ src/v/storage/probe.cc | 9 +++++++++ src/v/storage/probe.h | 11 +++++++++++ src/v/storage/record_batch_builder.cc | 9 +++++++++ src/v/storage/record_batch_builder.h | 11 +++++++++++ src/v/storage/segment.cc | 9 +++++++++ src/v/storage/segment.h | 11 +++++++++++ src/v/storage/segment_appender.cc | 9 +++++++++ src/v/storage/segment_appender.h | 11 +++++++++++ src/v/storage/segment_appender_chunk.h | 11 +++++++++++ src/v/storage/segment_appender_utils.cc | 9 +++++++++ src/v/storage/segment_appender_utils.h | 11 +++++++++++ src/v/storage/segment_index.cc | 9 +++++++++ src/v/storage/segment_index.h | 11 +++++++++++ src/v/storage/segment_reader.cc | 9 +++++++++ src/v/storage/segment_reader.h | 11 +++++++++++ src/v/storage/segment_set.cc | 9 +++++++++ src/v/storage/segment_set.h | 11 +++++++++++ src/v/storage/segment_utils.cc | 9 +++++++++ src/v/storage/segment_utils.h | 11 +++++++++++ src/v/storage/shard_assignment.h | 11 +++++++++++ src/v/storage/snapshot.cc | 9 +++++++++ src/v/storage/snapshot.h | 11 +++++++++++ src/v/storage/spill_key_index.cc | 9 +++++++++ src/v/storage/spill_key_index.h | 11 +++++++++++ src/v/storage/tests/appender_chunk_manipulations.cc | 9 +++++++++ src/v/storage/tests/batch_cache_reclaim_test.cc | 9 +++++++++ src/v/storage/tests/batch_cache_test.cc | 9 +++++++++ src/v/storage/tests/compaction_idx_bench.cc | 9 +++++++++ src/v/storage/tests/compaction_index_format_tests.cc | 9 +++++++++ src/v/storage/tests/disk_log_builder_fixture.h | 11 +++++++++++ src/v/storage/tests/disk_log_builder_test.cc | 9 +++++++++ src/v/storage/tests/half_page_concurrent_dispatch.cc | 9 +++++++++ src/v/storage/tests/kvstore_test.cc | 9 +++++++++ src/v/storage/tests/log_manager_test.cc | 9 +++++++++ src/v/storage/tests/log_replayer_test.cc | 9 +++++++++ src/v/storage/tests/log_retention_tests.cc | 9 +++++++++ src/v/storage/tests/log_segment_appender_test.cc | 9 +++++++++ src/v/storage/tests/log_segment_reader_test.cc | 9 +++++++++ src/v/storage/tests/log_truncate_test.cc | 9 +++++++++ src/v/storage/tests/offset_assignment_test.cc | 9 +++++++++ src/v/storage/tests/offset_index_utils_tests.cc | 9 +++++++++ src/v/storage/tests/parser_test.cc | 9 +++++++++ src/v/storage/tests/produce_consume_test.cc | 9 +++++++++ src/v/storage/tests/segment_size_jitter_test.cc | 9 +++++++++ src/v/storage/tests/snapshot_test.cc | 9 +++++++++ src/v/storage/tests/storage_e2e_test.cc | 9 +++++++++ src/v/storage/tests/storage_test_fixture.h | 11 +++++++++++ src/v/storage/tests/timequery_test.cc | 9 +++++++++ src/v/storage/tests/utils/disk_log_builder.cc | 9 +++++++++ src/v/storage/tests/utils/disk_log_builder.h | 11 +++++++++++ src/v/storage/tests/utils/random_batch.cc | 9 +++++++++ src/v/storage/tests/utils/random_batch.h | 11 +++++++++++ src/v/storage/types.cc | 9 +++++++++ src/v/storage/types.h | 11 +++++++++++ src/v/storage/version.h | 11 +++++++++++ src/v/syschecks/pidfile.cc | 9 +++++++++ src/v/syschecks/syschecks.cc | 9 +++++++++ src/v/syschecks/syschecks.h | 11 +++++++++++ src/v/test_utils/async.h | 11 +++++++++++ src/v/test_utils/fixture.h | 11 +++++++++++ src/v/test_utils/logs.h | 11 +++++++++++ src/v/test_utils/non_root_port.h | 11 +++++++++++ src/v/test_utils/randoms.h | 11 +++++++++++ src/v/test_utils/rpc.h | 11 +++++++++++ src/v/test_utils/seastar_testing_main.cc | 9 +++++++++ src/v/tristate.h | 11 +++++++++++ src/v/units.h | 11 +++++++++++ src/v/utils/concepts-enabled.h | 11 +++++++++++ src/v/utils/copy_range.h | 11 +++++++++++ src/v/utils/directory_walker.h | 11 +++++++++++ src/v/utils/expiring_promise.h | 11 +++++++++++ src/v/utils/file_io.h | 11 +++++++++++ src/v/utils/file_sanitizer.h | 11 +++++++++++ src/v/utils/hdr_hist.cc | 9 +++++++++ src/v/utils/hdr_hist.h | 11 +++++++++++ src/v/utils/human.cc | 9 +++++++++ src/v/utils/human.h | 11 +++++++++++ src/v/utils/intrusive_list_helpers.h | 11 +++++++++++ src/v/utils/memory_data_source.h | 11 +++++++++++ src/v/utils/mutex.h | 11 +++++++++++ src/v/utils/named_type.h | 11 +++++++++++ src/v/utils/remote.h | 11 +++++++++++ src/v/utils/retry.h | 11 +++++++++++ src/v/utils/state_crc_file.cc | 9 +++++++++ src/v/utils/state_crc_file.h | 11 +++++++++++ src/v/utils/state_crc_file_errc.h | 11 +++++++++++ src/v/utils/string_switch.h | 11 +++++++++++ src/v/utils/tests/constexpr_string_switch.cc | 9 +++++++++ src/v/utils/tests/directory_walker_test.cc | 9 +++++++++ src/v/utils/tests/named_type_tests.cc | 9 +++++++++ src/v/utils/tests/outcome_utils_test.cc | 9 +++++++++ src/v/utils/tests/remote_test.cc | 9 +++++++++ src/v/utils/tests/retry_test.cc | 9 +++++++++ src/v/utils/tests/state_crc_file_test.cc | 9 +++++++++ src/v/utils/tests/string_switch_test.cc | 9 +++++++++ src/v/utils/tests/tristate_test.cc | 9 +++++++++ src/v/utils/tests/vint_test.cc | 9 +++++++++ src/v/utils/to_string.h | 11 +++++++++++ src/v/utils/unresolved_address.h | 11 +++++++++++ src/v/utils/utf8.h | 11 +++++++++++ src/v/utils/vint.h | 11 +++++++++++ src/v/vassert.h | 11 +++++++++++ src/v/vlog.h | 11 +++++++++++ tests/rptest/__init__.py | 9 +++++++++ tests/rptest/chaos/__init__.py | 9 +++++++++ tests/rptest/chaos/kafkakv_muservice.py | 9 +++++++++ tests/rptest/chaos/mount_muservice.py | 9 +++++++++ tests/rptest/chaos/muservice.py | 9 +++++++++ tests/rptest/chaos/redpanda_duck_cluster.py | 9 +++++++++ tests/rptest/chaos/redpanda_muservice.py | 9 +++++++++ tests/rptest/chaos/templates/redpanda.yaml | 9 +++++++++ tests/rptest/clients/__init__.py | 9 +++++++++ tests/rptest/clients/compacted_verifier.py | 9 +++++++++ tests/rptest/clients/kafka_cat.py | 9 +++++++++ tests/rptest/clients/kafka_cli_tools.py | 9 +++++++++ tests/rptest/clients/rpk.py | 9 +++++++++ tests/rptest/services/__init__.py | 9 +++++++++ tests/rptest/services/kaf_consumer.py | 9 +++++++++ tests/rptest/services/kaf_producer.py | 9 +++++++++ tests/rptest/services/pandaproxy.py | 9 +++++++++ tests/rptest/services/redpanda.py | 9 +++++++++ tests/rptest/services/rpk_consumer.py | 9 +++++++++ tests/rptest/services/storage.py | 9 +++++++++ tests/rptest/services/templates/pandaproxy.yaml | 9 +++++++++ tests/rptest/services/templates/redpanda.yaml | 9 +++++++++ tests/rptest/test_suite_all.yml | 9 +++++++++ tests/rptest/test_suite_chaos.yml | 9 +++++++++ tests/rptest/test_suite_quick.yml | 9 +++++++++ tests/rptest/tests/__init__.py | 9 +++++++++ tests/rptest/tests/chaos/__init__.py | 9 +++++++++ tests/rptest/tests/chaos/baseline_test.py | 9 +++++++++ tests/rptest/tests/chaos/chaos_base_test.py | 9 +++++++++ tests/rptest/tests/chaos/isolate_follower_test.py | 9 +++++++++ tests/rptest/tests/chaos/isolate_leader_test.py | 9 +++++++++ tests/rptest/tests/chaos/ruinio_follower_test.py | 9 +++++++++ tests/rptest/tests/chaos/ruinio_leader_test.py | 9 +++++++++ tests/rptest/tests/chaos/slowio_follower_test.py | 9 +++++++++ tests/rptest/tests/chaos/slowio_leader_test.py | 9 +++++++++ tests/rptest/tests/chaos/suspend_follower_test.py | 9 +++++++++ tests/rptest/tests/chaos/suspend_leader_test.py | 9 +++++++++ tests/rptest/tests/chaos/terminate_follower_test.py | 9 +++++++++ tests/rptest/tests/chaos/terminate_leader_test.py | 9 +++++++++ .../tests/compacted_term_rolled_recovery_test.py | 9 +++++++++ tests/rptest/tests/compacted_topic_verifier_test.py | 9 +++++++++ tests/rptest/tests/compaction_recovery_test.py | 9 +++++++++ tests/rptest/tests/configuration_update_test.py | 9 +++++++++ tests/rptest/tests/controller_recovery_test.py | 9 +++++++++ tests/rptest/tests/demo_test.py | 9 +++++++++ tests/rptest/tests/describe_topics_test.py | 9 +++++++++ tests/rptest/tests/kafka_cli_tools_test.py | 9 +++++++++ tests/rptest/tests/leadership_transfer_test.py | 9 +++++++++ tests/rptest/tests/librdkafka_test.py | 9 +++++++++ tests/rptest/tests/pandaproxy_test.py | 9 +++++++++ tests/rptest/tests/prefix_truncate_recovery_test.py | 9 +++++++++ tests/rptest/tests/produce_bench_test.py | 9 +++++++++ tests/rptest/tests/redpanda_test.py | 9 +++++++++ tests/rptest/tests/rpk_test.py | 9 +++++++++ tests/rptest/tests/topic_delete_test.py | 9 +++++++++ tests/rptest/tests/wait_for_local_consumer_test.py | 9 +++++++++ tools/cmake_test.py | 9 +++++++++ tools/kafka-python-api-serde.py | 9 +++++++++ tools/rpcgen.py | 9 +++++++++ 991 files changed, 9581 insertions(+) diff --git a/.dir-locals.el b/.dir-locals.el index c9ea91880b3ee..9135f659de3b9 100644 --- a/.dir-locals.el +++ b/.dir-locals.el @@ -1,3 +1,12 @@ +;; Copyright 2020 Vectorized, Inc. +;; +;; Use of this software is governed by the Business Source License +;; included in the file licenses/BSL.md +;; +;; As of the Change Date specified in that file, in accordance with +;; the Business Source License, use of this software will be governed +;; by the Apache License, Version 2.0 + ;;; Directory Local Variables ;;; For more information see (info "(emacs) Directory Variables") diff --git a/.github/workflows/redpanda-build.yml b/.github/workflows/redpanda-build.yml index a0c71e13fe08c..5b9ec05241705 100644 --- a/.github/workflows/redpanda-build.yml +++ b/.github/workflows/redpanda-build.yml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + name: build-test on: [push, pull_request] diff --git a/.github/workflows/rpk-build.yml b/.github/workflows/rpk-build.yml index a94ec7e56f257..c22be1e4f893e 100644 --- a/.github/workflows/rpk-build.yml +++ b/.github/workflows/rpk-build.yml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + name: Go on: [push, pull_request] diff --git a/build.sh b/build.sh index 2611c416d6714..18a7e1474116c 100755 --- a/build.sh +++ b/build.sh @@ -1,4 +1,13 @@ #!/bin/bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -ex root="$(cd $(dirname ${BASH_SOURCE[0]}) && pwd)" if [[ -z ${CC} ]]; then export CC=/usr/bin/gcc; fi diff --git a/conf/pandaproxy.yaml b/conf/pandaproxy.yaml index 41692ae5bb488..ddc05b26d7a85 100644 --- a/conf/pandaproxy.yaml +++ b/conf/pandaproxy.yaml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # Pandaproxy configuration file # organization and cluster_id help Vectorized identify your system. diff --git a/conf/redpanda.yaml b/conf/redpanda.yaml index 6a93c23734b8c..296cece9c3932 100644 --- a/conf/redpanda.yaml +++ b/conf/redpanda.yaml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # Redpanda Queue configuration file # organization and cluster_id help Vectorized identify your system. diff --git a/install-dependencies.sh b/install-dependencies.sh index 66582a52fe445..b4445915185dd 100755 --- a/install-dependencies.sh +++ b/install-dependencies.sh @@ -1,4 +1,13 @@ #!/bin/bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + echo "installing seastar dependencies" diff --git a/src/consistency-testing/chaostest/chaostest/__init__.py b/src/consistency-testing/chaostest/chaostest/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/src/consistency-testing/chaostest/chaostest/__init__.py +++ b/src/consistency-testing/chaostest/chaostest/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/src/consistency-testing/chaostest/chaostest/faults.py b/src/consistency-testing/chaostest/chaostest/faults.py index 24eeef6ea8704..ba27cf36dc5ca 100644 --- a/src/consistency-testing/chaostest/chaostest/faults.py +++ b/src/consistency-testing/chaostest/chaostest/faults.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from gobekli.logging import m import logging import sys diff --git a/src/consistency-testing/chaostest/chaostest/kafka_cluster.py b/src/consistency-testing/chaostest/chaostest/kafka_cluster.py index bc203f300329b..0058c003a86a5 100644 --- a/src/consistency-testing/chaostest/chaostest/kafka_cluster.py +++ b/src/consistency-testing/chaostest/chaostest/kafka_cluster.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from sh import (ssh, scp) import sh import time diff --git a/src/consistency-testing/chaostest/chaostest/kvell_cluster.py b/src/consistency-testing/chaostest/chaostest/kvell_cluster.py index e30ecacca16d1..ea4fc79431bce 100644 --- a/src/consistency-testing/chaostest/chaostest/kvell_cluster.py +++ b/src/consistency-testing/chaostest/chaostest/kvell_cluster.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from sh import ssh import sh diff --git a/src/consistency-testing/chaostest/chaostest/redpanda_cluster.py b/src/consistency-testing/chaostest/chaostest/redpanda_cluster.py index 87498ddd126e6..6e8eacec6200f 100644 --- a/src/consistency-testing/chaostest/chaostest/redpanda_cluster.py +++ b/src/consistency-testing/chaostest/chaostest/redpanda_cluster.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from sh import ssh import sh import time diff --git a/src/consistency-testing/chaostest/control/kafka/continue-service.sh b/src/consistency-testing/chaostest/control/kafka/continue-service.sh index 1660055a75a79..9f8b865a9c52a 100755 --- a/src/consistency-testing/chaostest/control/kafka/continue-service.sh +++ b/src/consistency-testing/chaostest/control/kafka/continue-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/iofault.delay.sh b/src/consistency-testing/chaostest/control/kafka/iofault.delay.sh index 07ef3b38a6df8..1f34e99d5a25c 100755 --- a/src/consistency-testing/chaostest/control/kafka/iofault.delay.sh +++ b/src/consistency-testing/chaostest/control/kafka/iofault.delay.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/iofault.mount.sh b/src/consistency-testing/chaostest/control/kafka/iofault.mount.sh index 19f05ac670dbb..081d843c01425 100755 --- a/src/consistency-testing/chaostest/control/kafka/iofault.mount.sh +++ b/src/consistency-testing/chaostest/control/kafka/iofault.mount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/iofault.recover.sh b/src/consistency-testing/chaostest/control/kafka/iofault.recover.sh index 254f7d93e1e46..a0d764336cf9f 100755 --- a/src/consistency-testing/chaostest/control/kafka/iofault.recover.sh +++ b/src/consistency-testing/chaostest/control/kafka/iofault.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/iofault.ruin.sh b/src/consistency-testing/chaostest/control/kafka/iofault.ruin.sh index 5ca847665b430..708f94bfbfe8a 100755 --- a/src/consistency-testing/chaostest/control/kafka/iofault.ruin.sh +++ b/src/consistency-testing/chaostest/control/kafka/iofault.ruin.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/iofault.umount.sh b/src/consistency-testing/chaostest/control/kafka/iofault.umount.sh index eb5b6e85441f3..acd37444d2236 100755 --- a/src/consistency-testing/chaostest/control/kafka/iofault.umount.sh +++ b/src/consistency-testing/chaostest/control/kafka/iofault.umount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/is-service-running.sh b/src/consistency-testing/chaostest/control/kafka/is-service-running.sh index c7aeabd65a907..b47077d4456b8 100755 --- a/src/consistency-testing/chaostest/control/kafka/is-service-running.sh +++ b/src/consistency-testing/chaostest/control/kafka/is-service-running.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/isolate-bi.sh b/src/consistency-testing/chaostest/control/kafka/isolate-bi.sh index 68191f37fac47..e82d61a26e213 100755 --- a/src/consistency-testing/chaostest/control/kafka/isolate-bi.sh +++ b/src/consistency-testing/chaostest/control/kafka/isolate-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/kill-api.sh b/src/consistency-testing/chaostest/control/kafka/kill-api.sh index d3c2812528c26..cffd2e924b16d 100755 --- a/src/consistency-testing/chaostest/control/kafka/kill-api.sh +++ b/src/consistency-testing/chaostest/control/kafka/kill-api.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/kill-kafka.sh b/src/consistency-testing/chaostest/control/kafka/kill-kafka.sh index 72def7f769f32..9211ab148222b 100755 --- a/src/consistency-testing/chaostest/control/kafka/kill-kafka.sh +++ b/src/consistency-testing/chaostest/control/kafka/kill-kafka.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/kill-zookeeper.sh b/src/consistency-testing/chaostest/control/kafka/kill-zookeeper.sh index ad1b53cf44856..23056c6042a69 100755 --- a/src/consistency-testing/chaostest/control/kafka/kill-zookeeper.sh +++ b/src/consistency-testing/chaostest/control/kafka/kill-zookeeper.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/pause-service.sh b/src/consistency-testing/chaostest/control/kafka/pause-service.sh index e20499ae6847e..632ee4a220dc3 100755 --- a/src/consistency-testing/chaostest/control/kafka/pause-service.sh +++ b/src/consistency-testing/chaostest/control/kafka/pause-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/prep-dirs.sh b/src/consistency-testing/chaostest/control/kafka/prep-dirs.sh index 3c63940cc3aa6..ffd95c4471930 100755 --- a/src/consistency-testing/chaostest/control/kafka/prep-dirs.sh +++ b/src/consistency-testing/chaostest/control/kafka/prep-dirs.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/rejoin-bi.sh b/src/consistency-testing/chaostest/control/kafka/rejoin-bi.sh index 3848db16c6951..fd2e0a51f9936 100755 --- a/src/consistency-testing/chaostest/control/kafka/rejoin-bi.sh +++ b/src/consistency-testing/chaostest/control/kafka/rejoin-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/strobe.inject.sh b/src/consistency-testing/chaostest/control/kafka/strobe.inject.sh index 063d66592b546..7de810bb75c7d 100755 --- a/src/consistency-testing/chaostest/control/kafka/strobe.inject.sh +++ b/src/consistency-testing/chaostest/control/kafka/strobe.inject.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/strobe.kill.sh b/src/consistency-testing/chaostest/control/kafka/strobe.kill.sh index eb3bb124f1f47..c159187defe92 100755 --- a/src/consistency-testing/chaostest/control/kafka/strobe.kill.sh +++ b/src/consistency-testing/chaostest/control/kafka/strobe.kill.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/strobe.recover.sh b/src/consistency-testing/chaostest/control/kafka/strobe.recover.sh index 220ffa735f2d6..2217bd2a0d745 100755 --- a/src/consistency-testing/chaostest/control/kafka/strobe.recover.sh +++ b/src/consistency-testing/chaostest/control/kafka/strobe.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafka/wipe-out.sh b/src/consistency-testing/chaostest/control/kafka/wipe-out.sh index f15a7a7e2aab9..27decf6e972c4 100755 --- a/src/consistency-testing/chaostest/control/kafka/wipe-out.sh +++ b/src/consistency-testing/chaostest/control/kafka/wipe-out.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kafkakv.py b/src/consistency-testing/chaostest/control/kafkakv.py index 79d0df694e37d..150b8656b6b51 100644 --- a/src/consistency-testing/chaostest/control/kafkakv.py +++ b/src/consistency-testing/chaostest/control/kafkakv.py @@ -1,4 +1,13 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # pip3 install kafka-python flask # rpk api topic create -p 1 -r 3 topic3 diff --git a/src/consistency-testing/chaostest/control/kvelldb/continue-kvelldb.sh b/src/consistency-testing/chaostest/control/kvelldb/continue-kvelldb.sh index 824d94c5f9443..2c26eebf9310a 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/continue-kvelldb.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/continue-kvelldb.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/iofault.delay.sh b/src/consistency-testing/chaostest/control/kvelldb/iofault.delay.sh index 07ef3b38a6df8..1f34e99d5a25c 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/iofault.delay.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/iofault.delay.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/iofault.mount.sh b/src/consistency-testing/chaostest/control/kvelldb/iofault.mount.sh index fb4fb4dea0725..56b377e5e22a0 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/iofault.mount.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/iofault.mount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/iofault.recover.sh b/src/consistency-testing/chaostest/control/kvelldb/iofault.recover.sh index 254f7d93e1e46..a0d764336cf9f 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/iofault.recover.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/iofault.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/iofault.ruin.sh b/src/consistency-testing/chaostest/control/kvelldb/iofault.ruin.sh index 5ca847665b430..708f94bfbfe8a 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/iofault.ruin.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/iofault.ruin.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/iofault.umount.sh b/src/consistency-testing/chaostest/control/kvelldb/iofault.umount.sh index a9b3c9137e4fe..1f6fa2449b9a1 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/iofault.umount.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/iofault.umount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/is-kvelldb-running.sh b/src/consistency-testing/chaostest/control/kvelldb/is-kvelldb-running.sh index aab7869edfe9f..335ddb1b0aa16 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/is-kvelldb-running.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/is-kvelldb-running.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/isolate-bi.sh b/src/consistency-testing/chaostest/control/kvelldb/isolate-bi.sh index 68191f37fac47..e82d61a26e213 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/isolate-bi.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/isolate-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/kill-kvelldb.sh b/src/consistency-testing/chaostest/control/kvelldb/kill-kvelldb.sh index 7bffd715e5de6..aeb74d94e9869 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/kill-kvelldb.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/kill-kvelldb.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/pause-kvelldb.sh b/src/consistency-testing/chaostest/control/kvelldb/pause-kvelldb.sh index 59ceab8621b06..2f4af29787072 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/pause-kvelldb.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/pause-kvelldb.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/rejoin-bi.sh b/src/consistency-testing/chaostest/control/kvelldb/rejoin-bi.sh index 3848db16c6951..fd2e0a51f9936 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/rejoin-bi.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/rejoin-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/replica.sh b/src/consistency-testing/chaostest/control/kvelldb/replica.sh index 174c5b87fabda..ffe4f4214becb 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/replica.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/replica.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/strobe.inject.sh b/src/consistency-testing/chaostest/control/kvelldb/strobe.inject.sh index 8678d860c6f16..4a0328ab9064c 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/strobe.inject.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/strobe.inject.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/strobe.kill.sh b/src/consistency-testing/chaostest/control/kvelldb/strobe.kill.sh index eb3bb124f1f47..c159187defe92 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/strobe.kill.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/strobe.kill.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/strobe.recover.sh b/src/consistency-testing/chaostest/control/kvelldb/strobe.recover.sh index 220ffa735f2d6..2217bd2a0d745 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/strobe.recover.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/strobe.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/kvelldb/wipe-out.sh b/src/consistency-testing/chaostest/control/kvelldb/wipe-out.sh index 8bff054075851..d0b35c1577bd4 100755 --- a/src/consistency-testing/chaostest/control/kvelldb/wipe-out.sh +++ b/src/consistency-testing/chaostest/control/kvelldb/wipe-out.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/continue-service.sh b/src/consistency-testing/chaostest/control/redpanda/continue-service.sh index f5b1995326ff9..df6c4c6d7eb2f 100755 --- a/src/consistency-testing/chaostest/control/redpanda/continue-service.sh +++ b/src/consistency-testing/chaostest/control/redpanda/continue-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/create-topic.sh b/src/consistency-testing/chaostest/control/redpanda/create-topic.sh index 84a3213538338..a009bd89b9801 100755 --- a/src/consistency-testing/chaostest/control/redpanda/create-topic.sh +++ b/src/consistency-testing/chaostest/control/redpanda/create-topic.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/iofault.delay.sh b/src/consistency-testing/chaostest/control/redpanda/iofault.delay.sh index 07ef3b38a6df8..1f34e99d5a25c 100755 --- a/src/consistency-testing/chaostest/control/redpanda/iofault.delay.sh +++ b/src/consistency-testing/chaostest/control/redpanda/iofault.delay.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/iofault.mount.sh b/src/consistency-testing/chaostest/control/redpanda/iofault.mount.sh index a332075eea5b1..4dc6349fb1b47 100755 --- a/src/consistency-testing/chaostest/control/redpanda/iofault.mount.sh +++ b/src/consistency-testing/chaostest/control/redpanda/iofault.mount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/iofault.recover.sh b/src/consistency-testing/chaostest/control/redpanda/iofault.recover.sh index 254f7d93e1e46..a0d764336cf9f 100755 --- a/src/consistency-testing/chaostest/control/redpanda/iofault.recover.sh +++ b/src/consistency-testing/chaostest/control/redpanda/iofault.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/iofault.ruin.sh b/src/consistency-testing/chaostest/control/redpanda/iofault.ruin.sh index 5ca847665b430..708f94bfbfe8a 100755 --- a/src/consistency-testing/chaostest/control/redpanda/iofault.ruin.sh +++ b/src/consistency-testing/chaostest/control/redpanda/iofault.ruin.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/iofault.umount.sh b/src/consistency-testing/chaostest/control/redpanda/iofault.umount.sh index 072a9887d2bcb..59580830b488d 100755 --- a/src/consistency-testing/chaostest/control/redpanda/iofault.umount.sh +++ b/src/consistency-testing/chaostest/control/redpanda/iofault.umount.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/is-service-running.sh b/src/consistency-testing/chaostest/control/redpanda/is-service-running.sh index edf90452d240b..80c9570fe2b60 100755 --- a/src/consistency-testing/chaostest/control/redpanda/is-service-running.sh +++ b/src/consistency-testing/chaostest/control/redpanda/is-service-running.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/isolate-bi.sh b/src/consistency-testing/chaostest/control/redpanda/isolate-bi.sh index 68191f37fac47..e82d61a26e213 100755 --- a/src/consistency-testing/chaostest/control/redpanda/isolate-bi.sh +++ b/src/consistency-testing/chaostest/control/redpanda/isolate-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/kill-api.sh b/src/consistency-testing/chaostest/control/redpanda/kill-api.sh index 60259017d6430..f69963d532bcf 100755 --- a/src/consistency-testing/chaostest/control/redpanda/kill-api.sh +++ b/src/consistency-testing/chaostest/control/redpanda/kill-api.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/kill-service.sh b/src/consistency-testing/chaostest/control/redpanda/kill-service.sh index be77a1b3ac24c..5d67a4305d9c6 100755 --- a/src/consistency-testing/chaostest/control/redpanda/kill-service.sh +++ b/src/consistency-testing/chaostest/control/redpanda/kill-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/pause-service.sh b/src/consistency-testing/chaostest/control/redpanda/pause-service.sh index dcca754214294..9fa4ad9fb8692 100755 --- a/src/consistency-testing/chaostest/control/redpanda/pause-service.sh +++ b/src/consistency-testing/chaostest/control/redpanda/pause-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/rejoin-bi.sh b/src/consistency-testing/chaostest/control/redpanda/rejoin-bi.sh index 3848db16c6951..fd2e0a51f9936 100755 --- a/src/consistency-testing/chaostest/control/redpanda/rejoin-bi.sh +++ b/src/consistency-testing/chaostest/control/redpanda/rejoin-bi.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/start-service.sh b/src/consistency-testing/chaostest/control/redpanda/start-service.sh index a27ef189a96e9..b2dcff3867ccc 100755 --- a/src/consistency-testing/chaostest/control/redpanda/start-service.sh +++ b/src/consistency-testing/chaostest/control/redpanda/start-service.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/strobe.inject.sh b/src/consistency-testing/chaostest/control/redpanda/strobe.inject.sh index 063d66592b546..7de810bb75c7d 100755 --- a/src/consistency-testing/chaostest/control/redpanda/strobe.inject.sh +++ b/src/consistency-testing/chaostest/control/redpanda/strobe.inject.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/strobe.kill.sh b/src/consistency-testing/chaostest/control/redpanda/strobe.kill.sh index eb3bb124f1f47..c159187defe92 100755 --- a/src/consistency-testing/chaostest/control/redpanda/strobe.kill.sh +++ b/src/consistency-testing/chaostest/control/redpanda/strobe.kill.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/strobe.recover.sh b/src/consistency-testing/chaostest/control/redpanda/strobe.recover.sh index 220ffa735f2d6..2217bd2a0d745 100755 --- a/src/consistency-testing/chaostest/control/redpanda/strobe.recover.sh +++ b/src/consistency-testing/chaostest/control/redpanda/strobe.recover.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/redpanda/wipe-out.sh b/src/consistency-testing/chaostest/control/redpanda/wipe-out.sh index 8db4d6cb9dafc..0c76f72ec037b 100755 --- a/src/consistency-testing/chaostest/control/redpanda/wipe-out.sh +++ b/src/consistency-testing/chaostest/control/redpanda/wipe-out.sh @@ -1,4 +1,13 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + set -e diff --git a/src/consistency-testing/chaostest/control/strobe.py b/src/consistency-testing/chaostest/control/strobe.py index 3cf2941f276e7..f47444038e844 100644 --- a/src/consistency-testing/chaostest/control/strobe.py +++ b/src/consistency-testing/chaostest/control/strobe.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # https://docs.python.org/3/library/time.html # CLOCK_REALTIME # CLOCK_MONOTONIC¶ diff --git a/src/consistency-testing/chaostest/test-kafka.py b/src/consistency-testing/chaostest/test-kafka.py index 477bd73857486..f8f5d4b850a56 100644 --- a/src/consistency-testing/chaostest/test-kafka.py +++ b/src/consistency-testing/chaostest/test-kafka.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from gobekli.kvapi import KVNode from gobekli.workloads.symmetrical_mrsw import MRSWWorkload from gobekli.workloads.symmetrical_comrmw import COMRMWWorkload diff --git a/src/consistency-testing/chaostest/test-kvelldb.py b/src/consistency-testing/chaostest/test-kvelldb.py index 260d25a2005b4..1a568351f123d 100644 --- a/src/consistency-testing/chaostest/test-kvelldb.py +++ b/src/consistency-testing/chaostest/test-kvelldb.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from gobekli.kvapi import KVNode from gobekli.workloads.symmetrical_mrsw import MRSWWorkload from gobekli.workloads.symmetrical_comrmw import COMRMWWorkload diff --git a/src/consistency-testing/chaostest/test-redpanda.py b/src/consistency-testing/chaostest/test-redpanda.py index 40fcddeb3bdf2..0f4e6e0c4b949 100644 --- a/src/consistency-testing/chaostest/test-redpanda.py +++ b/src/consistency-testing/chaostest/test-redpanda.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from gobekli.kvapi import KVNode from gobekli.workloads.symmetrical_mrsw import MRSWWorkload from gobekli.workloads.symmetrical_comrmw import COMRMWWorkload diff --git a/src/consistency-testing/gobekli/gobekli/__init__.py b/src/consistency-testing/gobekli/gobekli/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/src/consistency-testing/gobekli/gobekli/__init__.py +++ b/src/consistency-testing/gobekli/gobekli/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/src/consistency-testing/gobekli/gobekli/chaos/__init__.py b/src/consistency-testing/gobekli/gobekli/chaos/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/src/consistency-testing/gobekli/gobekli/chaos/__init__.py +++ b/src/consistency-testing/gobekli/gobekli/chaos/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/src/consistency-testing/gobekli/gobekli/chaos/analysis.py b/src/consistency-testing/gobekli/gobekli/chaos/analysis.py index d856487c08baf..1e9b3aeaa1be1 100644 --- a/src/consistency-testing/gobekli/gobekli/chaos/analysis.py +++ b/src/consistency-testing/gobekli/gobekli/chaos/analysis.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from os import path from collections import defaultdict import os diff --git a/src/consistency-testing/gobekli/gobekli/chaos/main.py b/src/consistency-testing/gobekli/gobekli/chaos/main.py index d354cf1d02b6c..380567a596a4a 100644 --- a/src/consistency-testing/gobekli/gobekli/chaos/main.py +++ b/src/consistency-testing/gobekli/gobekli/chaos/main.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import asyncio from os import path import os diff --git a/src/consistency-testing/gobekli/gobekli/consensus.py b/src/consistency-testing/gobekli/gobekli/consensus.py index d0a2a0f5b5af9..1b92175405b4c 100644 --- a/src/consistency-testing/gobekli/gobekli/consensus.py +++ b/src/consistency-testing/gobekli/gobekli/consensus.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import logging from collections import namedtuple from gobekli.logging import m diff --git a/src/consistency-testing/gobekli/gobekli/kvapi.py b/src/consistency-testing/gobekli/gobekli/kvapi.py index 23320127c501a..610717048bb87 100644 --- a/src/consistency-testing/gobekli/gobekli/kvapi.py +++ b/src/consistency-testing/gobekli/gobekli/kvapi.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import asyncio import aiohttp import json diff --git a/src/consistency-testing/gobekli/gobekli/logging.py b/src/consistency-testing/gobekli/gobekli/logging.py index cdda5b159df15..283d13c381e69 100644 --- a/src/consistency-testing/gobekli/gobekli/logging.py +++ b/src/consistency-testing/gobekli/gobekli/logging.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import json import time import logging diff --git a/src/consistency-testing/gobekli/gobekli/workloads/__init__.py b/src/consistency-testing/gobekli/gobekli/workloads/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/src/consistency-testing/gobekli/gobekli/workloads/__init__.py +++ b/src/consistency-testing/gobekli/gobekli/workloads/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/src/consistency-testing/gobekli/gobekli/workloads/common.py b/src/consistency-testing/gobekli/gobekli/workloads/common.py index 19f589923964d..896335a9318b8 100644 --- a/src/consistency-testing/gobekli/gobekli/workloads/common.py +++ b/src/consistency-testing/gobekli/gobekli/workloads/common.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import asyncio import uuid import random diff --git a/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_comrmw.py b/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_comrmw.py index c01f3c4e3db1f..abb39fe87ce50 100644 --- a/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_comrmw.py +++ b/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_comrmw.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import asyncio import uuid import random diff --git a/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_mrsw.py b/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_mrsw.py index f30e1846f8be6..2aaddb4cc01b6 100644 --- a/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_mrsw.py +++ b/src/consistency-testing/gobekli/gobekli/workloads/symmetrical_mrsw.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import asyncio import uuid import random diff --git a/src/consistency-testing/gobekli/setup.py b/src/consistency-testing/gobekli/setup.py index c247fdc815085..e51339ea036fb 100644 --- a/src/consistency-testing/gobekli/setup.py +++ b/src/consistency-testing/gobekli/setup.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from setuptools import find_packages from setuptools import setup diff --git a/src/consistency-testing/gobekli/tests/__init__.py b/src/consistency-testing/gobekli/tests/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/src/consistency-testing/gobekli/tests/__init__.py +++ b/src/consistency-testing/gobekli/tests/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/src/consistency-testing/gobekli/tests/consensus.py b/src/consistency-testing/gobekli/tests/consensus.py index 38ef6cb82378d..793a908e68abc 100644 --- a/src/consistency-testing/gobekli/tests/consensus.py +++ b/src/consistency-testing/gobekli/tests/consensus.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from unittest import TestCase from gobekli.consensus import LinearizabilityRegisterChecker diff --git a/src/consistency-testing/iofaults/iofaults.py b/src/consistency-testing/iofaults/iofaults.py index a3197243d4a15..485d711c964bb 100755 --- a/src/consistency-testing/iofaults/iofaults.py +++ b/src/consistency-testing/iofaults/iofaults.py @@ -1,4 +1,13 @@ #!/usr/bin/env python +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import sys diff --git a/src/consistency-testing/kafka-availability/availability_logger.py b/src/consistency-testing/kafka-availability/availability_logger.py index fa7c838b8ac17..8647e5da39c87 100644 --- a/src/consistency-testing/kafka-availability/availability_logger.py +++ b/src/consistency-testing/kafka-availability/availability_logger.py @@ -1,4 +1,13 @@ #!/usr/bin/env python +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # pip3 install kafka-python # rpk api topic create -p 1 -r 3 topic1 diff --git a/src/go/rpk/pkg/api/api.go b/src/go/rpk/pkg/api/api.go index 34dce75314a7d..71802d7d91ad2 100644 --- a/src/go/rpk/pkg/api/api.go +++ b/src/go/rpk/pkg/api/api.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/api/api_test.go b/src/go/rpk/pkg/api/api_test.go index 73ba4e2616ce3..74fe8647605b0 100644 --- a/src/go/rpk/pkg/api/api_test.go +++ b/src/go/rpk/pkg/api/api_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api.go b/src/go/rpk/pkg/cli/cmd/api.go index ab468d7722c47..07312a16b7bf8 100644 --- a/src/go/rpk/pkg/cli/cmd/api.go +++ b/src/go/rpk/pkg/cli/cmd/api.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/consume.go b/src/go/rpk/pkg/cli/cmd/api/consume.go index c55f3fc484640..3637554eb7529 100644 --- a/src/go/rpk/pkg/cli/cmd/api/consume.go +++ b/src/go/rpk/pkg/cli/cmd/api/consume.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/consume_test.go b/src/go/rpk/pkg/cli/cmd/api/consume_test.go index 12719704a402b..ee3ce65234270 100644 --- a/src/go/rpk/pkg/cli/cmd/api/consume_test.go +++ b/src/go/rpk/pkg/cli/cmd/api/consume_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/produce.go b/src/go/rpk/pkg/cli/cmd/api/produce.go index d9fb5119482fd..2c5d3af508a9a 100644 --- a/src/go/rpk/pkg/cli/cmd/api/produce.go +++ b/src/go/rpk/pkg/cli/cmd/api/produce.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/produce_test.go b/src/go/rpk/pkg/cli/cmd/api/produce_test.go index 657acfd684a5b..c3b2d947e61c7 100644 --- a/src/go/rpk/pkg/cli/cmd/api/produce_test.go +++ b/src/go/rpk/pkg/cli/cmd/api/produce_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/status.go b/src/go/rpk/pkg/cli/cmd/api/status.go index 2b6d0c49ea94d..ee17e873c1025 100644 --- a/src/go/rpk/pkg/cli/cmd/api/status.go +++ b/src/go/rpk/pkg/cli/cmd/api/status.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/status_test.go b/src/go/rpk/pkg/cli/cmd/api/status_test.go index 4f58bef17a8b1..8902dad285af8 100644 --- a/src/go/rpk/pkg/cli/cmd/api/status_test.go +++ b/src/go/rpk/pkg/cli/cmd/api/status_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/topic.go b/src/go/rpk/pkg/cli/cmd/api/topic.go index 0337757f6a4e6..8d7c46872d831 100644 --- a/src/go/rpk/pkg/cli/cmd/api/topic.go +++ b/src/go/rpk/pkg/cli/cmd/api/topic.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/topic_test.go b/src/go/rpk/pkg/cli/cmd/api/topic_test.go index 7766edd594953..8359287cf521a 100644 --- a/src/go/rpk/pkg/cli/cmd/api/topic_test.go +++ b/src/go/rpk/pkg/cli/cmd/api/topic_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/api/utils.go b/src/go/rpk/pkg/cli/cmd/api/utils.go index d74ec148df938..6620ee08d5bf5 100644 --- a/src/go/rpk/pkg/cli/cmd/api/utils.go +++ b/src/go/rpk/pkg/cli/cmd/api/utils.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package api import ( diff --git a/src/go/rpk/pkg/cli/cmd/check.go b/src/go/rpk/pkg/cli/cmd/check.go index 88c1ca3bb0763..fcb2eaef3bc32 100644 --- a/src/go/rpk/pkg/cli/cmd/check.go +++ b/src/go/rpk/pkg/cli/cmd/check.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/config.go b/src/go/rpk/pkg/cli/cmd/config.go index 971418f922f6a..b02e57a78a50d 100644 --- a/src/go/rpk/pkg/cli/cmd/config.go +++ b/src/go/rpk/pkg/cli/cmd/config.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/config_test.go b/src/go/rpk/pkg/cli/cmd/config_test.go index 76d09cf5a6303..e00ec40e2e2b7 100644 --- a/src/go/rpk/pkg/cli/cmd/config_test.go +++ b/src/go/rpk/pkg/cli/cmd/config_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/container.go b/src/go/rpk/pkg/cli/cmd/container.go index 36944aa3ad9fd..5d80cccabac54 100644 --- a/src/go/rpk/pkg/cli/cmd/container.go +++ b/src/go/rpk/pkg/cli/cmd/container.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/common/client.go b/src/go/rpk/pkg/cli/cmd/container/common/client.go index cac80040fbcc7..899a55bd49934 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/client.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/client.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package common import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/common/common.go b/src/go/rpk/pkg/cli/cmd/container/common/common.go index da4ba4ddafd12..469b49df99384 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/common.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/common.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package common import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/common/test.go b/src/go/rpk/pkg/cli/cmd/container/common/test.go index 9c22d3d647cbf..529c6823c05b2 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/test.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package common import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/purge.go b/src/go/rpk/pkg/cli/cmd/container/purge.go index 8d6d8efe63ab3..e7366e4322127 100644 --- a/src/go/rpk/pkg/cli/cmd/container/purge.go +++ b/src/go/rpk/pkg/cli/cmd/container/purge.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/purge_test.go b/src/go/rpk/pkg/cli/cmd/container/purge_test.go index 1e2c8d1ee1445..32a61c56dd50b 100644 --- a/src/go/rpk/pkg/cli/cmd/container/purge_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/purge_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/start.go b/src/go/rpk/pkg/cli/cmd/container/start.go index 0169f0fbf3963..6ad628127d36d 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start.go +++ b/src/go/rpk/pkg/cli/cmd/container/start.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/start_darwin.go b/src/go/rpk/pkg/cli/cmd/container/start_darwin.go index fc526b3209d4e..d7b2b874cbbb2 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start_darwin.go +++ b/src/go/rpk/pkg/cli/cmd/container/start_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/start_linux.go b/src/go/rpk/pkg/cli/cmd/container/start_linux.go index 860a2bb35018d..3a5d4f329d624 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start_linux.go +++ b/src/go/rpk/pkg/cli/cmd/container/start_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import "vectorized/pkg/config" diff --git a/src/go/rpk/pkg/cli/cmd/container/start_test.go b/src/go/rpk/pkg/cli/cmd/container/start_test.go index 12d0ee18b0779..38b9bff367613 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/start_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/stop.go b/src/go/rpk/pkg/cli/cmd/container/stop.go index 25d76c5e6fd19..0ab1dc3aac37f 100644 --- a/src/go/rpk/pkg/cli/cmd/container/stop.go +++ b/src/go/rpk/pkg/cli/cmd/container/stop.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/container/stop_test.go b/src/go/rpk/pkg/cli/cmd/container/stop_test.go index ca84907e54a2a..6630ef6cd5730 100644 --- a/src/go/rpk/pkg/cli/cmd/container/stop_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/stop_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package container import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate.go b/src/go/rpk/pkg/cli/cmd/generate.go index 7bc296ea30c43..f80beb0f65c66 100644 --- a/src/go/rpk/pkg/cli/cmd/generate.go +++ b/src/go/rpk/pkg/cli/cmd/generate.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go b/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go index 531fc713858b0..7d06be7184481 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf import "encoding/json" diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard_test.go b/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard_test.go index 08057fed9c6c3..7920b1eee99ef 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go b/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go index c32059d99d483..65e83bcc92aeb 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf import "encoding/json" diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go b/src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go index 494175cb839fa..43be1cd3b5845 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/row.go b/src/go/rpk/pkg/cli/cmd/generate/graf/row.go index 9d4f2932ca6d1..79222773879f6 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/row.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/row.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf import "encoding/json" diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go b/src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go index 473c893a2e35b..fb84473e9ba97 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go b/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go index 484aaebf6c70d..d0c14b8f5c7d2 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf import "encoding/json" diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat_test.go b/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat_test.go index a0ac0be0ded5b..2ed8317fbcc71 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/graf/text.go b/src/go/rpk/pkg/cli/cmd/generate/graf/text.go index 8cc122a48ead2..92c9d02e24f65 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/text.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/text.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package graf import "encoding/json" diff --git a/src/go/rpk/pkg/cli/cmd/generate/grafana.go b/src/go/rpk/pkg/cli/cmd/generate/grafana.go index e79253c8571ab..d0c34d96db3e6 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/grafana.go +++ b/src/go/rpk/pkg/cli/cmd/generate/grafana.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package generate import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go b/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go index e187c0e5e8530..24b6950584f51 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package generate_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/generate/prometheus.go b/src/go/rpk/pkg/cli/cmd/generate/prometheus.go index 252e2ec75d6a0..1fa84c8f3be05 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/prometheus.go +++ b/src/go/rpk/pkg/cli/cmd/generate/prometheus.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package generate import ( diff --git a/src/go/rpk/pkg/cli/cmd/iotune.go b/src/go/rpk/pkg/cli/cmd/iotune.go index 4c9bec7689d84..e94a034a60c74 100644 --- a/src/go/rpk/pkg/cli/cmd/iotune.go +++ b/src/go/rpk/pkg/cli/cmd/iotune.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/iotune_test.go b/src/go/rpk/pkg/cli/cmd/iotune_test.go index 3f93727fb8b06..e7ddf1d98ff5a 100644 --- a/src/go/rpk/pkg/cli/cmd/iotune_test.go +++ b/src/go/rpk/pkg/cli/cmd/iotune_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/mode.go b/src/go/rpk/pkg/cli/cmd/mode.go index 854301475bfc8..cb71fcfc0a7f9 100644 --- a/src/go/rpk/pkg/cli/cmd/mode.go +++ b/src/go/rpk/pkg/cli/cmd/mode.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/mode_test.go b/src/go/rpk/pkg/cli/cmd/mode_test.go index bb7f4ccc7f3e3..6bd4933f4c9a8 100644 --- a/src/go/rpk/pkg/cli/cmd/mode_test.go +++ b/src/go/rpk/pkg/cli/cmd/mode_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/root.go b/src/go/rpk/pkg/cli/cmd/root.go index 202fa8e1b500d..1cd2161c4b0d8 100644 --- a/src/go/rpk/pkg/cli/cmd/root.go +++ b/src/go/rpk/pkg/cli/cmd/root.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/root_darwin.go b/src/go/rpk/pkg/cli/cmd/root_darwin.go index 0f1a32a0389ca..8f9f7a0be42b3 100644 --- a/src/go/rpk/pkg/cli/cmd/root_darwin.go +++ b/src/go/rpk/pkg/cli/cmd/root_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/root_linux.go b/src/go/rpk/pkg/cli/cmd/root_linux.go index 8b4a8ba3bb729..a32764bdf0535 100644 --- a/src/go/rpk/pkg/cli/cmd/root_linux.go +++ b/src/go/rpk/pkg/cli/cmd/root_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/start.go b/src/go/rpk/pkg/cli/cmd/start.go index 9fa6c2c2e6941..47ac20113e286 100644 --- a/src/go/rpk/pkg/cli/cmd/start.go +++ b/src/go/rpk/pkg/cli/cmd/start.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/start_test.go b/src/go/rpk/pkg/cli/cmd/start_test.go index 378870798da88..f5c7feee48fe9 100644 --- a/src/go/rpk/pkg/cli/cmd/start_test.go +++ b/src/go/rpk/pkg/cli/cmd/start_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/status.go b/src/go/rpk/pkg/cli/cmd/status.go index d0cc8c62db26d..82d830887b84e 100644 --- a/src/go/rpk/pkg/cli/cmd/status.go +++ b/src/go/rpk/pkg/cli/cmd/status.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/status_test.go b/src/go/rpk/pkg/cli/cmd/status_test.go index bd9b6d7d0d62a..b866410554fb6 100644 --- a/src/go/rpk/pkg/cli/cmd/status_test.go +++ b/src/go/rpk/pkg/cli/cmd/status_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/stop.go b/src/go/rpk/pkg/cli/cmd/stop.go index be0213f5a2b2d..c8129c9b6ef0c 100644 --- a/src/go/rpk/pkg/cli/cmd/stop.go +++ b/src/go/rpk/pkg/cli/cmd/stop.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/stop_test.go b/src/go/rpk/pkg/cli/cmd/stop_test.go index f9e92429c84b0..df5f3033a9fcb 100644 --- a/src/go/rpk/pkg/cli/cmd/stop_test.go +++ b/src/go/rpk/pkg/cli/cmd/stop_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd_test import ( diff --git a/src/go/rpk/pkg/cli/cmd/tune.go b/src/go/rpk/pkg/cli/cmd/tune.go index 917400068c8fe..562c1e6e92ac7 100644 --- a/src/go/rpk/pkg/cli/cmd/tune.go +++ b/src/go/rpk/pkg/cli/cmd/tune.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/tune/help.go b/src/go/rpk/pkg/cli/cmd/tune/help.go index 1e3268c68ebd5..316efb3683be4 100644 --- a/src/go/rpk/pkg/cli/cmd/tune/help.go +++ b/src/go/rpk/pkg/cli/cmd/tune/help.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tune import ( diff --git a/src/go/rpk/pkg/cli/cmd/tune_test.go b/src/go/rpk/pkg/cli/cmd/tune_test.go index 3b0bb810da120..587ab4369b95f 100644 --- a/src/go/rpk/pkg/cli/cmd/tune_test.go +++ b/src/go/rpk/pkg/cli/cmd/tune_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/version.go b/src/go/rpk/pkg/cli/cmd/version.go index 9ff81bfa8609c..228c443ce9509 100644 --- a/src/go/rpk/pkg/cli/cmd/version.go +++ b/src/go/rpk/pkg/cli/cmd/version.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/version/version.go b/src/go/rpk/pkg/cli/cmd/version/version.go index 8b883c453d9d4..d79b345bd6056 100644 --- a/src/go/rpk/pkg/cli/cmd/version/version.go +++ b/src/go/rpk/pkg/cli/cmd/version/version.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package version import "fmt" diff --git a/src/go/rpk/pkg/cli/cmd/wasm.go b/src/go/rpk/pkg/cli/cmd/wasm.go index fe200f36241af..112c18fcee3b3 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm.go +++ b/src/go/rpk/pkg/cli/cmd/wasm.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/cmd/wasm/generate.go b/src/go/rpk/pkg/cli/cmd/wasm/generate.go index 05b4fc9d5071d..40a23e6f0946c 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/generate.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/generate.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package transform import ( diff --git a/src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go b/src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go index cc925c2254963..07d0dcb1bea53 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package template const packageJson = `{ diff --git a/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go b/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go index 97eae0062b474..403cb7d4fd64f 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package template const wasmJs = `const { SimpleTransform, PolicyError } = require("../vectorized"); diff --git a/src/go/rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go b/src/go/rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go index 6e45cff43a029..379434f811add 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package template const wasmTestJS = `const transform = require("../src/wasm"); diff --git a/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go b/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go index bec622876fab5..08c70005f43cb 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package template const webpack = `#!/usr/bin/env node diff --git a/src/go/rpk/pkg/cli/cmd/wasm_test.go b/src/go/rpk/pkg/cli/cmd/wasm_test.go index c963d1a252f1a..146d8b9fdd47e 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm_test.go +++ b/src/go/rpk/pkg/cli/cmd/wasm_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cmd import ( diff --git a/src/go/rpk/pkg/cli/flags.go b/src/go/rpk/pkg/cli/flags.go index 42ac94f5f9cce..27b0a831ea9cf 100644 --- a/src/go/rpk/pkg/cli/flags.go +++ b/src/go/rpk/pkg/cli/flags.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cli import ( diff --git a/src/go/rpk/pkg/cli/log_formatter.go b/src/go/rpk/pkg/cli/log_formatter.go index 87d8b8c342dcd..20b3f2af73d33 100644 --- a/src/go/rpk/pkg/cli/log_formatter.go +++ b/src/go/rpk/pkg/cli/log_formatter.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cli import ( diff --git a/src/go/rpk/pkg/cli/ui/tables.go b/src/go/rpk/pkg/cli/ui/tables.go index f85bb44c4f60d..54d5e1891df42 100644 --- a/src/go/rpk/pkg/cli/ui/tables.go +++ b/src/go/rpk/pkg/cli/ui/tables.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package ui import ( diff --git a/src/go/rpk/pkg/cloud/aws/aws.go b/src/go/rpk/pkg/cloud/aws/aws.go index def172bf7ae6f..adfa60080380b 100644 --- a/src/go/rpk/pkg/cloud/aws/aws.go +++ b/src/go/rpk/pkg/cloud/aws/aws.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package aws import ( diff --git a/src/go/rpk/pkg/cloud/gcp/gcp.go b/src/go/rpk/pkg/cloud/gcp/gcp.go index 9bb696cd12cdb..ac4997cdb6e1f 100644 --- a/src/go/rpk/pkg/cloud/gcp/gcp.go +++ b/src/go/rpk/pkg/cloud/gcp/gcp.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package gcp import ( diff --git a/src/go/rpk/pkg/cloud/vendor/vendor.go b/src/go/rpk/pkg/cloud/vendor/vendor.go index bbc13a7542c0f..cd8a798df08f2 100644 --- a/src/go/rpk/pkg/cloud/vendor/vendor.go +++ b/src/go/rpk/pkg/cloud/vendor/vendor.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package vendor type Vendor interface { diff --git a/src/go/rpk/pkg/cloud/vendors.go b/src/go/rpk/pkg/cloud/vendors.go index 46d75adf85ca1..0d95b79f7b2e7 100644 --- a/src/go/rpk/pkg/cloud/vendors.go +++ b/src/go/rpk/pkg/cloud/vendors.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cloud import ( diff --git a/src/go/rpk/pkg/cloud/vendors_test.go b/src/go/rpk/pkg/cloud/vendors_test.go index 1a859b892a981..c272ffa3d69b3 100644 --- a/src/go/rpk/pkg/cloud/vendors_test.go +++ b/src/go/rpk/pkg/cloud/vendors_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cloud import ( diff --git a/src/go/rpk/pkg/cmd/groupcsaw/main.go b/src/go/rpk/pkg/cmd/groupcsaw/main.go index 20cf354307db0..59e7f22e2575b 100644 --- a/src/go/rpk/pkg/cmd/groupcsaw/main.go +++ b/src/go/rpk/pkg/cmd/groupcsaw/main.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package main import ( diff --git a/src/go/rpk/pkg/cmd/kverify/main.go b/src/go/rpk/pkg/cmd/kverify/main.go index b840d31fc3d2f..7ecca744526d7 100644 --- a/src/go/rpk/pkg/cmd/kverify/main.go +++ b/src/go/rpk/pkg/cmd/kverify/main.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package main import ( diff --git a/src/go/rpk/pkg/cmd/kverify/stats.go b/src/go/rpk/pkg/cmd/kverify/stats.go index 5d892dbf71109..ec0eeac72b901 100644 --- a/src/go/rpk/pkg/cmd/kverify/stats.go +++ b/src/go/rpk/pkg/cmd/kverify/stats.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package main import ( diff --git a/src/go/rpk/pkg/cmd/rpk/main.go b/src/go/rpk/pkg/cmd/rpk/main.go index c0d3390131f69..a03ae9b743aff 100644 --- a/src/go/rpk/pkg/cmd/rpk/main.go +++ b/src/go/rpk/pkg/cmd/rpk/main.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package main import "vectorized/pkg/cli/cmd" diff --git a/src/go/rpk/pkg/config/config.go b/src/go/rpk/pkg/config/config.go index 272f58918d9c6..a2888ae87271f 100644 --- a/src/go/rpk/pkg/config/config.go +++ b/src/go/rpk/pkg/config/config.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config import ( diff --git a/src/go/rpk/pkg/config/config_test.go b/src/go/rpk/pkg/config/config_test.go index 73fdbcbd700bf..11bb7a6989af0 100644 --- a/src/go/rpk/pkg/config/config_test.go +++ b/src/go/rpk/pkg/config/config_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config import ( diff --git a/src/go/rpk/pkg/config/find.go b/src/go/rpk/pkg/config/find.go index 85dd49d0ef9c9..8e161439984a1 100644 --- a/src/go/rpk/pkg/config/find.go +++ b/src/go/rpk/pkg/config/find.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config import ( diff --git a/src/go/rpk/pkg/config/find_test.go b/src/go/rpk/pkg/config/find_test.go index 776fde9cb99fc..9ba9b3cff8f37 100644 --- a/src/go/rpk/pkg/config/find_test.go +++ b/src/go/rpk/pkg/config/find_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config import ( diff --git a/src/go/rpk/pkg/config/license.go b/src/go/rpk/pkg/config/license.go index c8653dd00c95b..ec6aeb04011cd 100644 --- a/src/go/rpk/pkg/config/license.go +++ b/src/go/rpk/pkg/config/license.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config import ( diff --git a/src/go/rpk/pkg/config/license_test.go b/src/go/rpk/pkg/config/license_test.go index ce80aed2c5963..dfc5094e87b05 100644 --- a/src/go/rpk/pkg/config/license_test.go +++ b/src/go/rpk/pkg/config/license_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package config_test import ( diff --git a/src/go/rpk/pkg/kafka/client.go b/src/go/rpk/pkg/kafka/client.go index f6eb2f12eb5c8..bc49bdfd7196a 100644 --- a/src/go/rpk/pkg/kafka/client.go +++ b/src/go/rpk/pkg/kafka/client.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package kafka import ( diff --git a/src/go/rpk/pkg/net/interfaces.go b/src/go/rpk/pkg/net/interfaces.go index 839afbf68adce..a2682bc28b062 100644 --- a/src/go/rpk/pkg/net/interfaces.go +++ b/src/go/rpk/pkg/net/interfaces.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package net import ( diff --git a/src/go/rpk/pkg/os/commands.go b/src/go/rpk/pkg/os/commands.go index c6066c716a00b..9efa770f8a556 100644 --- a/src/go/rpk/pkg/os/commands.go +++ b/src/go/rpk/pkg/os/commands.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package os import "time" diff --git a/src/go/rpk/pkg/os/lock.go b/src/go/rpk/pkg/os/lock.go index 9ab64eab7d1a0..d60583a3ecf34 100644 --- a/src/go/rpk/pkg/os/lock.go +++ b/src/go/rpk/pkg/os/lock.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package os import ( diff --git a/src/go/rpk/pkg/os/proc.go b/src/go/rpk/pkg/os/proc.go index c5507b1fa0a21..850b7a8e90f30 100644 --- a/src/go/rpk/pkg/os/proc.go +++ b/src/go/rpk/pkg/os/proc.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package os import ( diff --git a/src/go/rpk/pkg/os/proc_test.go b/src/go/rpk/pkg/os/proc_test.go index ccfb7afdde9d2..9917440e329dd 100644 --- a/src/go/rpk/pkg/os/proc_test.go +++ b/src/go/rpk/pkg/os/proc_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package os_test import ( diff --git a/src/go/rpk/pkg/redpanda/launcher.go b/src/go/rpk/pkg/redpanda/launcher.go index 0a43e07471f5d..60865612efa36 100644 --- a/src/go/rpk/pkg/redpanda/launcher.go +++ b/src/go/rpk/pkg/redpanda/launcher.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package redpanda import ( diff --git a/src/go/rpk/pkg/redpanda/launcher_test.go b/src/go/rpk/pkg/redpanda/launcher_test.go index 635125a868bd9..d506c374eaff6 100644 --- a/src/go/rpk/pkg/redpanda/launcher_test.go +++ b/src/go/rpk/pkg/redpanda/launcher_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package redpanda import ( diff --git a/src/go/rpk/pkg/redpanda/paths.go b/src/go/rpk/pkg/redpanda/paths.go index 91438f2978648..bf246c47ded5c 100644 --- a/src/go/rpk/pkg/redpanda/paths.go +++ b/src/go/rpk/pkg/redpanda/paths.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package redpanda import ( diff --git a/src/go/rpk/pkg/system/cgroup.go b/src/go/rpk/pkg/system/cgroup.go index 49ab85164900d..a8eb4c6515cad 100644 --- a/src/go/rpk/pkg/system/cgroup.go +++ b/src/go/rpk/pkg/system/cgroup.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/cgroup_test.go b/src/go/rpk/pkg/system/cgroup_test.go index 05d4924562354..d8c1d38c9a9bc 100644 --- a/src/go/rpk/pkg/system/cgroup_test.go +++ b/src/go/rpk/pkg/system/cgroup_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system_test import ( diff --git a/src/go/rpk/pkg/system/cpu.go b/src/go/rpk/pkg/system/cpu.go index 8d3d4964b7a0f..0d12143c883b5 100644 --- a/src/go/rpk/pkg/system/cpu.go +++ b/src/go/rpk/pkg/system/cpu.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import "github.com/shirou/gopsutil/cpu" diff --git a/src/go/rpk/pkg/system/filesystem/fs.go b/src/go/rpk/pkg/system/filesystem/fs.go index 164aee183269f..a45fdc7a52576 100644 --- a/src/go/rpk/pkg/system/filesystem/fs.go +++ b/src/go/rpk/pkg/system/filesystem/fs.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package filesystem import ( diff --git a/src/go/rpk/pkg/system/filesystem/fs_darwin.go b/src/go/rpk/pkg/system/filesystem/fs_darwin.go index 6da7bdbd41a6b..60ecf6e9335c8 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_darwin.go +++ b/src/go/rpk/pkg/system/filesystem/fs_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package filesystem import "errors" diff --git a/src/go/rpk/pkg/system/filesystem/fs_linux.go b/src/go/rpk/pkg/system/filesystem/fs_linux.go index cd78f86a29237..540a630a6604e 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_linux.go +++ b/src/go/rpk/pkg/system/filesystem/fs_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package filesystem import ( diff --git a/src/go/rpk/pkg/system/filesystem/fs_test.go b/src/go/rpk/pkg/system/filesystem/fs_test.go index 15788a5de1eae..e5c198080fdaa 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_test.go +++ b/src/go/rpk/pkg/system/filesystem/fs_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package filesystem import ( diff --git a/src/go/rpk/pkg/system/filesystem/types.go b/src/go/rpk/pkg/system/filesystem/types.go index 3b9ca9f89e4b7..d9fa0abd8e9d0 100644 --- a/src/go/rpk/pkg/system/filesystem/types.go +++ b/src/go/rpk/pkg/system/filesystem/types.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package filesystem type FsType string diff --git a/src/go/rpk/pkg/system/grub.go b/src/go/rpk/pkg/system/grub.go index 84cf1b3eb52b9..32a7c9f4781ee 100644 --- a/src/go/rpk/pkg/system/grub.go +++ b/src/go/rpk/pkg/system/grub.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/grub_test.go b/src/go/rpk/pkg/system/grub_test.go index 83cafd9a4cea3..f3fe1fe735f6e 100644 --- a/src/go/rpk/pkg/system/grub_test.go +++ b/src/go/rpk/pkg/system/grub_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/memory.go b/src/go/rpk/pkg/system/memory.go index 25f6f91e877a8..12762caeeb740 100644 --- a/src/go/rpk/pkg/system/memory.go +++ b/src/go/rpk/pkg/system/memory.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/memory_darwin.go b/src/go/rpk/pkg/system/memory_darwin.go index 30118b613b210..e4936adff742e 100644 --- a/src/go/rpk/pkg/system/memory_darwin.go +++ b/src/go/rpk/pkg/system/memory_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/memory_linux.go b/src/go/rpk/pkg/system/memory_linux.go index c0694f7ff4482..b52687d159b4c 100644 --- a/src/go/rpk/pkg/system/memory_linux.go +++ b/src/go/rpk/pkg/system/memory_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/metrics.go b/src/go/rpk/pkg/system/metrics.go index 230776f786641..8af07ee73ba50 100644 --- a/src/go/rpk/pkg/system/metrics.go +++ b/src/go/rpk/pkg/system/metrics.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/ntp.go b/src/go/rpk/pkg/system/ntp.go index 1bf03b53bb8a1..1fcb402d58bc4 100644 --- a/src/go/rpk/pkg/system/ntp.go +++ b/src/go/rpk/pkg/system/ntp.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/ntp_test.go b/src/go/rpk/pkg/system/ntp_test.go index c976483019e42..45b86615b31ec 100644 --- a/src/go/rpk/pkg/system/ntp_test.go +++ b/src/go/rpk/pkg/system/ntp_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/runtime_options.go b/src/go/rpk/pkg/system/runtime_options.go index 604813a41fc1e..caa68d68e0c57 100644 --- a/src/go/rpk/pkg/system/runtime_options.go +++ b/src/go/rpk/pkg/system/runtime_options.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/runtime_options_test.go b/src/go/rpk/pkg/system/runtime_options_test.go index 2b6ca3c2090c5..61580213f4561 100644 --- a/src/go/rpk/pkg/system/runtime_options_test.go +++ b/src/go/rpk/pkg/system/runtime_options_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/systemd/client.go b/src/go/rpk/pkg/system/systemd/client.go index 4936e12bc119c..ae71d4cdb7f3c 100644 --- a/src/go/rpk/pkg/system/systemd/client.go +++ b/src/go/rpk/pkg/system/systemd/client.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package systemd import ( diff --git a/src/go/rpk/pkg/system/systemd/dbus.go b/src/go/rpk/pkg/system/systemd/dbus.go index 04248ad316cf1..24c210c22f164 100644 --- a/src/go/rpk/pkg/system/systemd/dbus.go +++ b/src/go/rpk/pkg/system/systemd/dbus.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package systemd import ( diff --git a/src/go/rpk/pkg/system/systemd/mock.go b/src/go/rpk/pkg/system/systemd/mock.go index ff2e699d991ca..bb1ede117827d 100644 --- a/src/go/rpk/pkg/system/systemd/mock.go +++ b/src/go/rpk/pkg/system/systemd/mock.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package systemd import "github.com/spf13/afero" diff --git a/src/go/rpk/pkg/system/utils.go b/src/go/rpk/pkg/system/utils.go index cc18673d5b115..4f903724b6d79 100644 --- a/src/go/rpk/pkg/system/utils.go +++ b/src/go/rpk/pkg/system/utils.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import ( diff --git a/src/go/rpk/pkg/system/utils_darwin.go b/src/go/rpk/pkg/system/utils_darwin.go index 976a8599afb5f..adafbc6b13c3f 100644 --- a/src/go/rpk/pkg/system/utils_darwin.go +++ b/src/go/rpk/pkg/system/utils_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import "errors" diff --git a/src/go/rpk/pkg/system/utils_linux.go b/src/go/rpk/pkg/system/utils_linux.go index b6e7b7732b310..431bae88d6beb 100644 --- a/src/go/rpk/pkg/system/utils_linux.go +++ b/src/go/rpk/pkg/system/utils_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package system import "syscall" diff --git a/src/go/rpk/pkg/tuners/aggregated_tunable.go b/src/go/rpk/pkg/tuners/aggregated_tunable.go index 57b40e799fa70..ddd1a183b2883 100644 --- a/src/go/rpk/pkg/tuners/aggregated_tunable.go +++ b/src/go/rpk/pkg/tuners/aggregated_tunable.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners func NewAggregatedTunable(tunables []Tunable) Tunable { diff --git a/src/go/rpk/pkg/tuners/aggregated_tunable_test.go b/src/go/rpk/pkg/tuners/aggregated_tunable_test.go index 9a9c6e937f70f..0f502d2b624d8 100644 --- a/src/go/rpk/pkg/tuners/aggregated_tunable_test.go +++ b/src/go/rpk/pkg/tuners/aggregated_tunable_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/aio.go b/src/go/rpk/pkg/tuners/aio.go index 1e5a6abb0d45a..5988071717d8d 100644 --- a/src/go/rpk/pkg/tuners/aio.go +++ b/src/go/rpk/pkg/tuners/aio.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/aio_test.go b/src/go/rpk/pkg/tuners/aio_test.go index 1abe2c2c9c191..477137752ea4f 100644 --- a/src/go/rpk/pkg/tuners/aio_test.go +++ b/src/go/rpk/pkg/tuners/aio_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners_test import ( diff --git a/src/go/rpk/pkg/tuners/check.go b/src/go/rpk/pkg/tuners/check.go index f5af0c47fdc21..9c43bbe601209 100644 --- a/src/go/rpk/pkg/tuners/check.go +++ b/src/go/rpk/pkg/tuners/check.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/checked_tunable.go b/src/go/rpk/pkg/tuners/checked_tunable.go index 5d1c3225f248d..9be60d9adbbca 100644 --- a/src/go/rpk/pkg/tuners/checked_tunable.go +++ b/src/go/rpk/pkg/tuners/checked_tunable.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/checked_tunable_test.go b/src/go/rpk/pkg/tuners/checked_tunable_test.go index 316e058ff0580..a1f6a0e4c1c53 100644 --- a/src/go/rpk/pkg/tuners/checked_tunable_test.go +++ b/src/go/rpk/pkg/tuners/checked_tunable_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/checker.go b/src/go/rpk/pkg/tuners/checker.go index a8f9df427ef9f..93de8f6f2ddf2 100644 --- a/src/go/rpk/pkg/tuners/checker.go +++ b/src/go/rpk/pkg/tuners/checker.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners type Severity byte diff --git a/src/go/rpk/pkg/tuners/clocksource.go b/src/go/rpk/pkg/tuners/clocksource.go index 44ab1f803330e..d7e4a51ca3967 100644 --- a/src/go/rpk/pkg/tuners/clocksource.go +++ b/src/go/rpk/pkg/tuners/clocksource.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/coredump/tuner.go b/src/go/rpk/pkg/tuners/coredump/tuner.go index ef0cee98591ea..264f4dbeadc71 100644 --- a/src/go/rpk/pkg/tuners/coredump/tuner.go +++ b/src/go/rpk/pkg/tuners/coredump/tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package coredump import ( diff --git a/src/go/rpk/pkg/tuners/coredump/tuner_test.go b/src/go/rpk/pkg/tuners/coredump/tuner_test.go index 8ae7d8a614557..db5ec55f4875c 100644 --- a/src/go/rpk/pkg/tuners/coredump/tuner_test.go +++ b/src/go/rpk/pkg/tuners/coredump/tuner_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package coredump import ( diff --git a/src/go/rpk/pkg/tuners/cpu/tuner.go b/src/go/rpk/pkg/tuners/cpu/tuner.go index 4771a39852211..11d804289c262 100644 --- a/src/go/rpk/pkg/tuners/cpu/tuner.go +++ b/src/go/rpk/pkg/tuners/cpu/tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package cpu import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_device.go b/src/go/rpk/pkg/tuners/disk/block_device.go index a07c1b0ef9854..52b980fbb94ee 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device.go +++ b/src/go/rpk/pkg/tuners/disk/block_device.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_device_darwin.go b/src/go/rpk/pkg/tuners/disk/block_device_darwin.go index f2ed883b28e92..90ac0792ddc7b 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_darwin.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_device_linux.go b/src/go/rpk/pkg/tuners/disk/block_device_linux.go index 428064c805a65..56693410bddfa 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_linux.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_device_test.go b/src/go/rpk/pkg/tuners/disk/block_device_test.go index 1adbc8047da33..2e7fb167d0d23 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_test.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_devices.go b/src/go/rpk/pkg/tuners/disk/block_devices.go index 853226732e861..cd66c0fb47d63 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go b/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go index 14fbed0b356f2..775a448a92d61 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import "syscall" diff --git a/src/go/rpk/pkg/tuners/disk/block_devices_linux.go b/src/go/rpk/pkg/tuners/disk/block_devices_linux.go index f615356cecede..259d3bedcb1ec 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_linux.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import "syscall" diff --git a/src/go/rpk/pkg/tuners/disk/block_devices_test.go b/src/go/rpk/pkg/tuners/disk/block_devices_test.go index fe00c07e127ca..d12fc54778fd7 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_test.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/scheduler_info.go b/src/go/rpk/pkg/tuners/disk/scheduler_info.go index 98dfefd76013f..6ee5482d4aef3 100644 --- a/src/go/rpk/pkg/tuners/disk/scheduler_info.go +++ b/src/go/rpk/pkg/tuners/disk/scheduler_info.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk/scheduler_info_test.go b/src/go/rpk/pkg/tuners/disk/scheduler_info_test.go index 7be7dbeae5f57..8fbfba98df563 100644 --- a/src/go/rpk/pkg/tuners/disk/scheduler_info_test.go +++ b/src/go/rpk/pkg/tuners/disk/scheduler_info_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package disk import ( diff --git a/src/go/rpk/pkg/tuners/disk_checkers.go b/src/go/rpk/pkg/tuners/disk_checkers.go index 10dab85e767aa..51240fd23b8ac 100644 --- a/src/go/rpk/pkg/tuners/disk_checkers.go +++ b/src/go/rpk/pkg/tuners/disk_checkers.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go b/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go index c4592c29cd4dc..65d85d233a757 100644 --- a/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go b/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go index 212c4c79947be..c25fb630ddc71 100644 --- a/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go b/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go index 2631a81824966..74262c56d6908 100644 --- a/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go b/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go index 03d3b7e2bd2bb..a93005a4fe1ca 100644 --- a/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disk_tuner.go b/src/go/rpk/pkg/tuners/disk_tuner.go index ea4304b1d60da..b63f2702a7802 100644 --- a/src/go/rpk/pkg/tuners/disk_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disks_irq_tuner.go b/src/go/rpk/pkg/tuners/disks_irq_tuner.go index 779d4bd8227d0..d955bfe281b05 100644 --- a/src/go/rpk/pkg/tuners/disks_irq_tuner.go +++ b/src/go/rpk/pkg/tuners/disks_irq_tuner.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go b/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go index cd476665f1db0..a62fd55c3815e 100644 --- a/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/equality_checker.go b/src/go/rpk/pkg/tuners/equality_checker.go index 5858c65d429e8..879228b8bee9f 100644 --- a/src/go/rpk/pkg/tuners/equality_checker.go +++ b/src/go/rpk/pkg/tuners/equality_checker.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/equality_checker_test.go b/src/go/rpk/pkg/tuners/equality_checker_test.go index e9371b58f96ab..db1800c073cc9 100644 --- a/src/go/rpk/pkg/tuners/equality_checker_test.go +++ b/src/go/rpk/pkg/tuners/equality_checker_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/ethtool/ethtool.go b/src/go/rpk/pkg/tuners/ethtool/ethtool.go index 7a0b2e77746ea..7e2da7cbf7ad1 100644 --- a/src/go/rpk/pkg/tuners/ethtool/ethtool.go +++ b/src/go/rpk/pkg/tuners/ethtool/ethtool.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package ethtool import "github.com/safchain/ethtool" diff --git a/src/go/rpk/pkg/tuners/executors/commands/backup_file.go b/src/go/rpk/pkg/tuners/executors/commands/backup_file.go index 8f36c3bab835d..224f2acd7c25b 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/backup_file.go +++ b/src/go/rpk/pkg/tuners/executors/commands/backup_file.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/command.go b/src/go/rpk/pkg/tuners/executors/commands/command.go index dd53e84e0df04..9611f10f825c3 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/command.go +++ b/src/go/rpk/pkg/tuners/executors/commands/command.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import "bufio" diff --git a/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go b/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go index c45c0ea82f2bb..1df84622f12fc 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go +++ b/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/execute.go b/src/go/rpk/pkg/tuners/executors/commands/execute.go index 563d5bc665253..32486dc6a94fd 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/execute.go +++ b/src/go/rpk/pkg/tuners/executors/commands/execute.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go b/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go index 3bb9c2bc3288b..109f05220b008 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go +++ b/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit.go b/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit.go index 5d5a66e0faf98..0534e8d56d0d5 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit.go +++ b/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit_test.go b/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit_test.go index 8f80d76364cfa..965223f825971 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit_test.go +++ b/src/go/rpk/pkg/tuners/executors/commands/systemd_install_unit_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands_test import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit.go b/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit.go index 8a6b889ad91d8..34132a54ada30 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit.go +++ b/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit_test.go b/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit_test.go index 30521a7cb06da..843a80e0e29d5 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit_test.go +++ b/src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands_test import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/write_file.go b/src/go/rpk/pkg/tuners/executors/commands/write_file.go index b0493d727acf6..befa972bd1c58 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_file.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_file.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/write_file_lines.go b/src/go/rpk/pkg/tuners/executors/commands/write_file_lines.go index 04f65781c1147..4f912ad91a50d 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_file_lines.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_file_lines.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands import ( diff --git a/src/go/rpk/pkg/tuners/executors/commands/write_file_test.go b/src/go/rpk/pkg/tuners/executors/commands/write_file_test.go index 79883096e734e..d13b23fd0dc04 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_file_test.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_file_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package commands_test import ( diff --git a/src/go/rpk/pkg/tuners/executors/direct.go b/src/go/rpk/pkg/tuners/executors/direct.go index 7d5d166a2b597..03904500789c6 100644 --- a/src/go/rpk/pkg/tuners/executors/direct.go +++ b/src/go/rpk/pkg/tuners/executors/direct.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package executors import "vectorized/pkg/tuners/executors/commands" diff --git a/src/go/rpk/pkg/tuners/executors/executor.go b/src/go/rpk/pkg/tuners/executors/executor.go index 306057f4ba027..9e1a69e82717e 100644 --- a/src/go/rpk/pkg/tuners/executors/executor.go +++ b/src/go/rpk/pkg/tuners/executors/executor.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package executors import "vectorized/pkg/tuners/executors/commands" diff --git a/src/go/rpk/pkg/tuners/executors/script_rendering.go b/src/go/rpk/pkg/tuners/executors/script_rendering.go index 2dd1900f62315..c3c576e5109fe 100644 --- a/src/go/rpk/pkg/tuners/executors/script_rendering.go +++ b/src/go/rpk/pkg/tuners/executors/script_rendering.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package executors import ( diff --git a/src/go/rpk/pkg/tuners/factory/factory.go b/src/go/rpk/pkg/tuners/factory/factory.go index d218262ac3501..4f9ce94282409 100644 --- a/src/go/rpk/pkg/tuners/factory/factory.go +++ b/src/go/rpk/pkg/tuners/factory/factory.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package factory import ( diff --git a/src/go/rpk/pkg/tuners/factory/factory_test.go b/src/go/rpk/pkg/tuners/factory/factory_test.go index b2305dbd97a41..a1195b8ac980f 100644 --- a/src/go/rpk/pkg/tuners/factory/factory_test.go +++ b/src/go/rpk/pkg/tuners/factory/factory_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package factory_test import ( diff --git a/src/go/rpk/pkg/tuners/file_existance_checker.go b/src/go/rpk/pkg/tuners/file_existance_checker.go index 1faa1191f9bbb..8ad04be80aef7 100644 --- a/src/go/rpk/pkg/tuners/file_existance_checker.go +++ b/src/go/rpk/pkg/tuners/file_existance_checker.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "github.com/spf13/afero" diff --git a/src/go/rpk/pkg/tuners/float_checker.go b/src/go/rpk/pkg/tuners/float_checker.go index f8f5d54fc990c..334c6aba0884b 100644 --- a/src/go/rpk/pkg/tuners/float_checker.go +++ b/src/go/rpk/pkg/tuners/float_checker.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "fmt" diff --git a/src/go/rpk/pkg/tuners/float_checker_test.go b/src/go/rpk/pkg/tuners/float_checker_test.go index 0f8ec42de96ec..85a80d5dc76a8 100644 --- a/src/go/rpk/pkg/tuners/float_checker_test.go +++ b/src/go/rpk/pkg/tuners/float_checker_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/fstrim.go b/src/go/rpk/pkg/tuners/fstrim.go index 6adb50b03fab7..857506c95a821 100644 --- a/src/go/rpk/pkg/tuners/fstrim.go +++ b/src/go/rpk/pkg/tuners/fstrim.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/fstrim_test.go b/src/go/rpk/pkg/tuners/fstrim_test.go index 7cd2f8b7a3676..968eb758b5bb5 100644 --- a/src/go/rpk/pkg/tuners/fstrim_test.go +++ b/src/go/rpk/pkg/tuners/fstrim_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/hwloc/cpuset.go b/src/go/rpk/pkg/tuners/hwloc/cpuset.go index e68886b16abcb..d9d37b1b6b3bc 100644 --- a/src/go/rpk/pkg/tuners/hwloc/cpuset.go +++ b/src/go/rpk/pkg/tuners/hwloc/cpuset.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package hwloc import ( diff --git a/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go b/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go index 068aa58ef799b..20168dc15621b 100644 --- a/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go +++ b/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package hwloc import ( diff --git a/src/go/rpk/pkg/tuners/hwloc/hwloc.go b/src/go/rpk/pkg/tuners/hwloc/hwloc.go index 975ed22ef512b..ee7530c01fbb7 100644 --- a/src/go/rpk/pkg/tuners/hwloc/hwloc.go +++ b/src/go/rpk/pkg/tuners/hwloc/hwloc.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package hwloc type HwLoc interface { diff --git a/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go b/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go index 186c8bf09b720..9fa9c04d026b8 100644 --- a/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go +++ b/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package hwloc import ( diff --git a/src/go/rpk/pkg/tuners/int_checker.go b/src/go/rpk/pkg/tuners/int_checker.go index 95d275ae769c8..89407773e1c2a 100644 --- a/src/go/rpk/pkg/tuners/int_checker.go +++ b/src/go/rpk/pkg/tuners/int_checker.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "strconv" diff --git a/src/go/rpk/pkg/tuners/int_checker_test.go b/src/go/rpk/pkg/tuners/int_checker_test.go index 6a6ef3301c8c1..9e9b026ce56d5 100644 --- a/src/go/rpk/pkg/tuners/int_checker_test.go +++ b/src/go/rpk/pkg/tuners/int_checker_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/iotune.go b/src/go/rpk/pkg/tuners/iotune.go index c19927d85d641..34a3c18d94532 100644 --- a/src/go/rpk/pkg/tuners/iotune.go +++ b/src/go/rpk/pkg/tuners/iotune.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/iotune/data.go b/src/go/rpk/pkg/tuners/iotune/data.go index 581e180c35456..7730074e7e2db 100644 --- a/src/go/rpk/pkg/tuners/iotune/data.go +++ b/src/go/rpk/pkg/tuners/iotune/data.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package iotune import ( diff --git a/src/go/rpk/pkg/tuners/iotune/data_test.go b/src/go/rpk/pkg/tuners/iotune/data_test.go index b688a1eeef155..26ffd711f614e 100644 --- a/src/go/rpk/pkg/tuners/iotune/data_test.go +++ b/src/go/rpk/pkg/tuners/iotune/data_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package iotune_test import ( diff --git a/src/go/rpk/pkg/tuners/iotune/io_tune.go b/src/go/rpk/pkg/tuners/iotune/io_tune.go index b5aa1ffaae29c..0edf26d890ad2 100644 --- a/src/go/rpk/pkg/tuners/iotune/io_tune.go +++ b/src/go/rpk/pkg/tuners/iotune/io_tune.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package iotune import ( diff --git a/src/go/rpk/pkg/tuners/irq/balance_service.go b/src/go/rpk/pkg/tuners/irq/balance_service.go index 5fbc3e24afd9d..64d816b7a1892 100644 --- a/src/go/rpk/pkg/tuners/irq/balance_service.go +++ b/src/go/rpk/pkg/tuners/irq/balance_service.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/balance_service_test.go b/src/go/rpk/pkg/tuners/irq/balance_service_test.go index 2ec36600f45de..129ee59a22efc 100644 --- a/src/go/rpk/pkg/tuners/irq/balance_service_test.go +++ b/src/go/rpk/pkg/tuners/irq/balance_service_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/cpu_masks.go b/src/go/rpk/pkg/tuners/irq/cpu_masks.go index 1de666abc5d4b..d47fa28fdab34 100644 --- a/src/go/rpk/pkg/tuners/irq/cpu_masks.go +++ b/src/go/rpk/pkg/tuners/irq/cpu_masks.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go b/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go index c81bc5b89dfda..9abf5833e7c9b 100644 --- a/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go +++ b/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/device_info.go b/src/go/rpk/pkg/tuners/irq/device_info.go index 741e4e77edf11..39be2d182bce9 100644 --- a/src/go/rpk/pkg/tuners/irq/device_info.go +++ b/src/go/rpk/pkg/tuners/irq/device_info.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/device_info_test.go b/src/go/rpk/pkg/tuners/irq/device_info_test.go index 9c33c9c47c2ea..2e2f77984fc64 100644 --- a/src/go/rpk/pkg/tuners/irq/device_info_test.go +++ b/src/go/rpk/pkg/tuners/irq/device_info_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go b/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go index c25ab9ee0e613..e2f4c22951335 100644 --- a/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go +++ b/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq /* diff --git a/src/go/rpk/pkg/tuners/irq/proc_file.go b/src/go/rpk/pkg/tuners/irq/proc_file.go index b99012740fe2a..19823a8ab8571 100644 --- a/src/go/rpk/pkg/tuners/irq/proc_file.go +++ b/src/go/rpk/pkg/tuners/irq/proc_file.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/proc_file_test.go b/src/go/rpk/pkg/tuners/irq/proc_file_test.go index 4aa81427ccbb2..7ebf48a029335 100644 --- a/src/go/rpk/pkg/tuners/irq/proc_file_test.go +++ b/src/go/rpk/pkg/tuners/irq/proc_file_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import ( diff --git a/src/go/rpk/pkg/tuners/irq/utils.go b/src/go/rpk/pkg/tuners/irq/utils.go index 6a21b29f52a6a..6617020d61747 100644 --- a/src/go/rpk/pkg/tuners/irq/utils.go +++ b/src/go/rpk/pkg/tuners/irq/utils.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package irq import "vectorized/pkg/utils" diff --git a/src/go/rpk/pkg/tuners/kernel_version.go b/src/go/rpk/pkg/tuners/kernel_version.go index 6d929f9f96d72..ddee077245f84 100644 --- a/src/go/rpk/pkg/tuners/kernel_version.go +++ b/src/go/rpk/pkg/tuners/kernel_version.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "fmt" diff --git a/src/go/rpk/pkg/tuners/kernel_version_darwin.go b/src/go/rpk/pkg/tuners/kernel_version_darwin.go index ff23b44c4d526..ec9e82083d7e4 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_darwin.go +++ b/src/go/rpk/pkg/tuners/kernel_version_darwin.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "errors" diff --git a/src/go/rpk/pkg/tuners/kernel_version_linux.go b/src/go/rpk/pkg/tuners/kernel_version_linux.go index 74b8c29916607..6fc8d593b9c18 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_linux.go +++ b/src/go/rpk/pkg/tuners/kernel_version_linux.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import "syscall" diff --git a/src/go/rpk/pkg/tuners/kernel_version_test.go b/src/go/rpk/pkg/tuners/kernel_version_test.go index 2304d3215df63..8c332a0a3bd4d 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_test.go +++ b/src/go/rpk/pkg/tuners/kernel_version_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/net_checkers.go b/src/go/rpk/pkg/tuners/net_checkers.go index 2013b3a7dafab..b476300013d6c 100644 --- a/src/go/rpk/pkg/tuners/net_checkers.go +++ b/src/go/rpk/pkg/tuners/net_checkers.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/net_tuners.go b/src/go/rpk/pkg/tuners/net_tuners.go index bbb07fa4a1504..9ea967078375a 100644 --- a/src/go/rpk/pkg/tuners/net_tuners.go +++ b/src/go/rpk/pkg/tuners/net_tuners.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/net_tuners_test.go b/src/go/rpk/pkg/tuners/net_tuners_test.go index 60055915fb321..ba8cda5f102b8 100644 --- a/src/go/rpk/pkg/tuners/net_tuners_test.go +++ b/src/go/rpk/pkg/tuners/net_tuners_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners_test import ( diff --git a/src/go/rpk/pkg/tuners/network/const.go b/src/go/rpk/pkg/tuners/network/const.go index 2f6bbf3e981bf..8c5a53bf43ab0 100644 --- a/src/go/rpk/pkg/tuners/network/const.go +++ b/src/go/rpk/pkg/tuners/network/const.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package network const ( diff --git a/src/go/rpk/pkg/tuners/network/nic.go b/src/go/rpk/pkg/tuners/network/nic.go index 932c76c44aeca..219b78690def3 100644 --- a/src/go/rpk/pkg/tuners/network/nic.go +++ b/src/go/rpk/pkg/tuners/network/nic.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package network import ( diff --git a/src/go/rpk/pkg/tuners/network/nic_test.go b/src/go/rpk/pkg/tuners/network/nic_test.go index 76750f3c0897e..ad2157a70e08e 100644 --- a/src/go/rpk/pkg/tuners/network/nic_test.go +++ b/src/go/rpk/pkg/tuners/network/nic_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package network import ( diff --git a/src/go/rpk/pkg/tuners/network/nics.go b/src/go/rpk/pkg/tuners/network/nics.go index bf27ac538748b..4d3292df8e878 100644 --- a/src/go/rpk/pkg/tuners/network/nics.go +++ b/src/go/rpk/pkg/tuners/network/nics.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package network import ( diff --git a/src/go/rpk/pkg/tuners/redpanda_checkers.go b/src/go/rpk/pkg/tuners/redpanda_checkers.go index a537fc4d6e455..b63cbf59f8ca1 100644 --- a/src/go/rpk/pkg/tuners/redpanda_checkers.go +++ b/src/go/rpk/pkg/tuners/redpanda_checkers.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/redpanda_checkers_test.go b/src/go/rpk/pkg/tuners/redpanda_checkers_test.go index df8b000637858..02c98ae3529b9 100644 --- a/src/go/rpk/pkg/tuners/redpanda_checkers_test.go +++ b/src/go/rpk/pkg/tuners/redpanda_checkers_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners_test import ( diff --git a/src/go/rpk/pkg/tuners/swappiness.go b/src/go/rpk/pkg/tuners/swappiness.go index 1ddf9fece3e23..f5435e297eac5 100644 --- a/src/go/rpk/pkg/tuners/swappiness.go +++ b/src/go/rpk/pkg/tuners/swappiness.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/swappiness_test.go b/src/go/rpk/pkg/tuners/swappiness_test.go index d76739ac69210..e14a277b5e35c 100644 --- a/src/go/rpk/pkg/tuners/swappiness_test.go +++ b/src/go/rpk/pkg/tuners/swappiness_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners_test import ( diff --git a/src/go/rpk/pkg/tuners/thp.go b/src/go/rpk/pkg/tuners/thp.go index cdddb3e11a393..a3d5913d0d581 100644 --- a/src/go/rpk/pkg/tuners/thp.go +++ b/src/go/rpk/pkg/tuners/thp.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/tuners/thp_test.go b/src/go/rpk/pkg/tuners/thp_test.go index 626bc7ea9ed3c..8406a15aafd09 100644 --- a/src/go/rpk/pkg/tuners/thp_test.go +++ b/src/go/rpk/pkg/tuners/thp_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners_test import ( diff --git a/src/go/rpk/pkg/tuners/tunable.go b/src/go/rpk/pkg/tuners/tunable.go index 8d8a3244a9c83..807a86d9090a5 100644 --- a/src/go/rpk/pkg/tuners/tunable.go +++ b/src/go/rpk/pkg/tuners/tunable.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners type Tunable interface { diff --git a/src/go/rpk/pkg/tuners/tune_result.go b/src/go/rpk/pkg/tuners/tune_result.go index bff07e4fd9ed1..f3e4b480cfad8 100644 --- a/src/go/rpk/pkg/tuners/tune_result.go +++ b/src/go/rpk/pkg/tuners/tune_result.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners type TuneResult interface { diff --git a/src/go/rpk/pkg/tuners/tune_result_test.go b/src/go/rpk/pkg/tuners/tune_result_test.go index e0dc62449af2c..f9e46c7089ca3 100644 --- a/src/go/rpk/pkg/tuners/tune_result_test.go +++ b/src/go/rpk/pkg/tuners/tune_result_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package tuners import ( diff --git a/src/go/rpk/pkg/utils/chained_error.go b/src/go/rpk/pkg/utils/chained_error.go index ca1beefdb8cd4..c5fc39bdc30c3 100644 --- a/src/go/rpk/pkg/utils/chained_error.go +++ b/src/go/rpk/pkg/utils/chained_error.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils import "fmt" diff --git a/src/go/rpk/pkg/utils/collect.go b/src/go/rpk/pkg/utils/collect.go index 1a41d70b3c6bd..f3714cf77037c 100644 --- a/src/go/rpk/pkg/utils/collect.go +++ b/src/go/rpk/pkg/utils/collect.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils func GetKeys(setMap map[string]bool) []string { diff --git a/src/go/rpk/pkg/utils/files.go b/src/go/rpk/pkg/utils/files.go index 58a4e5e3486ed..96b830de93b42 100644 --- a/src/go/rpk/pkg/utils/files.go +++ b/src/go/rpk/pkg/utils/files.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils import ( diff --git a/src/go/rpk/pkg/utils/files_test.go b/src/go/rpk/pkg/utils/files_test.go index 7ebe7c5f619f3..d34aa4ccde6c2 100644 --- a/src/go/rpk/pkg/utils/files_test.go +++ b/src/go/rpk/pkg/utils/files_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils_test import ( diff --git a/src/go/rpk/pkg/utils/os.go b/src/go/rpk/pkg/utils/os.go index 3fae95989fafc..1a9b5790e6699 100644 --- a/src/go/rpk/pkg/utils/os.go +++ b/src/go/rpk/pkg/utils/os.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils import ( diff --git a/src/go/rpk/pkg/utils/strings.go b/src/go/rpk/pkg/utils/strings.go index 726d388a4cc50..434be504a19aa 100644 --- a/src/go/rpk/pkg/utils/strings.go +++ b/src/go/rpk/pkg/utils/strings.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils func StringInSlice(str string, ss []string) bool { diff --git a/src/go/rpk/pkg/utils/strings_test.go b/src/go/rpk/pkg/utils/strings_test.go index 927408d11daf9..fe490d8ff4304 100644 --- a/src/go/rpk/pkg/utils/strings_test.go +++ b/src/go/rpk/pkg/utils/strings_test.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package utils_test import ( diff --git a/src/go/rpk/pkg/yaml/yaml.go b/src/go/rpk/pkg/yaml/yaml.go index bb376974eec79..f21ad5ddc741b 100644 --- a/src/go/rpk/pkg/yaml/yaml.go +++ b/src/go/rpk/pkg/yaml/yaml.go @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + package yaml import ( diff --git a/src/v/bytes/bytes.cc b/src/v/bytes/bytes.cc index 35657ee637895..a62395539ad46 100644 --- a/src/v/bytes/bytes.cc +++ b/src/v/bytes/bytes.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/bytes.h" ss::sstring to_hex(bytes_view b) { diff --git a/src/v/bytes/bytes.h b/src/v/bytes/bytes.h index 2598b10686afd..c495fc2f3a5be 100644 --- a/src/v/bytes/bytes.h +++ b/src/v/bytes/bytes.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/bytes/details/io_allocation_size.h b/src/v/bytes/details/io_allocation_size.h index 1a45d97d321bd..3233ccd07c004 100644 --- a/src/v/bytes/details/io_allocation_size.h +++ b/src/v/bytes/details/io_allocation_size.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/bytes/details/io_byte_iterator.h b/src/v/bytes/details/io_byte_iterator.h index 4e958f0f3563d..6ccb743cceadf 100644 --- a/src/v/bytes/details/io_byte_iterator.h +++ b/src/v/bytes/details/io_byte_iterator.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/io_fragment.h" diff --git a/src/v/bytes/details/io_fragment.h b/src/v/bytes/details/io_fragment.h index 8f0a68909b95b..f772249032e30 100644 --- a/src/v/bytes/details/io_fragment.h +++ b/src/v/bytes/details/io_fragment.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/out_of_range.h" diff --git a/src/v/bytes/details/io_iterator_consumer.h b/src/v/bytes/details/io_iterator_consumer.h index 85d4a9b422148..b9f535a44a41d 100644 --- a/src/v/bytes/details/io_iterator_consumer.h +++ b/src/v/bytes/details/io_iterator_consumer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/io_byte_iterator.h" diff --git a/src/v/bytes/details/io_placeholder.h b/src/v/bytes/details/io_placeholder.h index e3f04a1f1aed1..e4b4b22a6c6e3 100644 --- a/src/v/bytes/details/io_placeholder.h +++ b/src/v/bytes/details/io_placeholder.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/io_fragment.h" diff --git a/src/v/bytes/details/out_of_range.h b/src/v/bytes/details/out_of_range.h index eb9e1564c1c1f..3e0e2f80fa08d 100644 --- a/src/v/bytes/details/out_of_range.h +++ b/src/v/bytes/details/out_of_range.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/bytes/iobuf.cc b/src/v/bytes/iobuf.cc index 508afdb4dd56a..c4f7d4cdf487a 100644 --- a/src/v/bytes/iobuf.cc +++ b/src/v/bytes/iobuf.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "bytes/details/io_allocation_size.h" diff --git a/src/v/bytes/iobuf.h b/src/v/bytes/iobuf.h index a642592e3b068..61a07d3e73af2 100644 --- a/src/v/bytes/iobuf.h +++ b/src/v/bytes/iobuf.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/io_allocation_size.h" #include "bytes/details/io_byte_iterator.h" diff --git a/src/v/bytes/iobuf_file.h b/src/v/bytes/iobuf_file.h index 4207d0aa0c904..645409d302b28 100644 --- a/src/v/bytes/iobuf_file.h +++ b/src/v/bytes/iobuf_file.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "vlog.h" diff --git a/src/v/bytes/iobuf_ostreambuf.h b/src/v/bytes/iobuf_ostreambuf.h index 4657ad0ad71d9..7a530dd8de498 100644 --- a/src/v/bytes/iobuf_ostreambuf.h +++ b/src/v/bytes/iobuf_ostreambuf.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/bytes/iobuf_parser.h b/src/v/bytes/iobuf_parser.h index e98c506b11d2f..25714e0f3ae64 100644 --- a/src/v/bytes/iobuf_parser.h +++ b/src/v/bytes/iobuf_parser.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/bytes/tests/iobuf_tests.cc b/src/v/bytes/tests/iobuf_tests.cc index ece44841a1476..bbe9fc330b08d 100644 --- a/src/v/bytes/tests/iobuf_tests.cc +++ b/src/v/bytes/tests/iobuf_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/bytes.h" #include "bytes/details/io_allocation_size.h" #include "bytes/iobuf.h" diff --git a/src/v/bytes/tests/iobuf_utils_tests.cc b/src/v/bytes/tests/iobuf_utils_tests.cc index 813850055b5b7..99d1fadf51977 100644 --- a/src/v/bytes/tests/iobuf_utils_tests.cc +++ b/src/v/bytes/tests/iobuf_utils_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/tests/utils.h" #include diff --git a/src/v/bytes/tests/utils.h b/src/v/bytes/tests/utils.h index f049a8096afcd..66f0655fa31d4 100644 --- a/src/v/bytes/tests/utils.h +++ b/src/v/bytes/tests/utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "random/generators.h" diff --git a/src/v/bytes/utils.h b/src/v/bytes/utils.h index 4a42cb4c914eb..3adf975f81aa0 100644 --- a/src/v/bytes/utils.h +++ b/src/v/bytes/utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "hashing/crc32c.h" diff --git a/src/v/cluster/cluster_utils.cc b/src/v/cluster/cluster_utils.cc index 2014cca5535f3..b8b12d585cbb0 100644 --- a/src/v/cluster/cluster_utils.cc +++ b/src/v/cluster/cluster_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/cluster_utils.h" #include "cluster/logger.h" diff --git a/src/v/cluster/cluster_utils.h b/src/v/cluster/cluster_utils.h index 7d9d1dde9ee76..5b4189fa97672 100644 --- a/src/v/cluster/cluster_utils.h +++ b/src/v/cluster/cluster_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller_service.h" #include "cluster/errc.h" diff --git a/src/v/cluster/commands.h b/src/v/cluster/commands.h index e15ce66442828..131a1739603a2 100644 --- a/src/v/cluster/commands.h +++ b/src/v/cluster/commands.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf_parser.h" #include "cluster/simple_batch_builder.h" diff --git a/src/v/cluster/controller.cc b/src/v/cluster/controller.cc index c434339a1190a..9e4578cf3e165 100644 --- a/src/v/cluster/controller.cc +++ b/src/v/cluster/controller.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/controller.h" #include "cluster/cluster_utils.h" diff --git a/src/v/cluster/controller.h b/src/v/cluster/controller.h index 6a7b8c960183d..aecdbeea71c7d 100644 --- a/src/v/cluster/controller.h +++ b/src/v/cluster/controller.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller_backend.h" diff --git a/src/v/cluster/controller_backend.cc b/src/v/cluster/controller_backend.cc index ee150d9197f59..7504a7ae4fc72 100644 --- a/src/v/cluster/controller_backend.cc +++ b/src/v/cluster/controller_backend.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/controller_backend.h" diff --git a/src/v/cluster/controller_backend.h b/src/v/cluster/controller_backend.h index 0ffa7b8dcedc2..7e4df2fb196fb 100644 --- a/src/v/cluster/controller_backend.h +++ b/src/v/cluster/controller_backend.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/members_table.h" diff --git a/src/v/cluster/controller_stm.h b/src/v/cluster/controller_stm.h index f76ff1ffdb709..76bd046f6dc16 100644 --- a/src/v/cluster/controller_stm.h +++ b/src/v/cluster/controller_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/topic_table.h" diff --git a/src/v/cluster/errc.h b/src/v/cluster/errc.h index f34cabba7fc95..d05a19d5ca85e 100644 --- a/src/v/cluster/errc.h +++ b/src/v/cluster/errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/cluster/logger.cc b/src/v/cluster/logger.cc index cdb03123c94de..950684993b36d 100644 --- a/src/v/cluster/logger.cc +++ b/src/v/cluster/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/logger.h" namespace cluster { diff --git a/src/v/cluster/logger.h b/src/v/cluster/logger.h index 83546edacd595..6e7cf319de8b8 100644 --- a/src/v/cluster/logger.h +++ b/src/v/cluster/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/cluster/members_manager.cc b/src/v/cluster/members_manager.cc index 36bee0931e8fe..e455417e02885 100644 --- a/src/v/cluster/members_manager.cc +++ b/src/v/cluster/members_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/members_manager.h" #include "cluster/cluster_utils.h" diff --git a/src/v/cluster/members_manager.h b/src/v/cluster/members_manager.h index 054f8d454f2dd..5153864a4a4a1 100644 --- a/src/v/cluster/members_manager.h +++ b/src/v/cluster/members_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/members_table.h" diff --git a/src/v/cluster/members_table.cc b/src/v/cluster/members_table.cc index 8ad45f18f0281..69f7f44236aea 100644 --- a/src/v/cluster/members_table.cc +++ b/src/v/cluster/members_table.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/members_table.h" #include "model/metadata.h" diff --git a/src/v/cluster/members_table.h b/src/v/cluster/members_table.h index db265339c7f7f..bdd647f0e1725 100644 --- a/src/v/cluster/members_table.h +++ b/src/v/cluster/members_table.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/types.h" diff --git a/src/v/cluster/metadata_cache.cc b/src/v/cluster/metadata_cache.cc index b8bdd8de30dab..0ab9df0992fbf 100644 --- a/src/v/cluster/metadata_cache.cc +++ b/src/v/cluster/metadata_cache.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_cache.h" #include "cluster/namespace.h" diff --git a/src/v/cluster/metadata_cache.h b/src/v/cluster/metadata_cache.h index b67f16a08cc6e..71baf7e7af888 100644 --- a/src/v/cluster/metadata_cache.h +++ b/src/v/cluster/metadata_cache.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/members_table.h" diff --git a/src/v/cluster/metadata_dissemination_handler.cc b/src/v/cluster/metadata_dissemination_handler.cc index e2a463c6faded..e25a0b9c366cb 100644 --- a/src/v/cluster/metadata_dissemination_handler.cc +++ b/src/v/cluster/metadata_dissemination_handler.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_dissemination_handler.h" #include "cluster/cluster_utils.h" diff --git a/src/v/cluster/metadata_dissemination_handler.h b/src/v/cluster/metadata_dissemination_handler.h index 8f659559fadad..c4ff86c3a52f2 100644 --- a/src/v/cluster/metadata_dissemination_handler.h +++ b/src/v/cluster/metadata_dissemination_handler.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/metadata_cache.h" diff --git a/src/v/cluster/metadata_dissemination_service.cc b/src/v/cluster/metadata_dissemination_service.cc index 0a10600d45b3a..1b5134edaf05c 100644 --- a/src/v/cluster/metadata_dissemination_service.cc +++ b/src/v/cluster/metadata_dissemination_service.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_dissemination_service.h" #include "cluster/cluster_utils.h" diff --git a/src/v/cluster/metadata_dissemination_service.h b/src/v/cluster/metadata_dissemination_service.h index f1505dc439551..59175859026ec 100644 --- a/src/v/cluster/metadata_dissemination_service.h +++ b/src/v/cluster/metadata_dissemination_service.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/members_table.h" diff --git a/src/v/cluster/metadata_dissemination_types.h b/src/v/cluster/metadata_dissemination_types.h index 84a760517fa01..94bbfcd0a8b05 100644 --- a/src/v/cluster/metadata_dissemination_types.h +++ b/src/v/cluster/metadata_dissemination_types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/metadata.h" diff --git a/src/v/cluster/metadata_dissemination_utils.cc b/src/v/cluster/metadata_dissemination_utils.cc index 3258967a4d040..6a31b3ec5f4f5 100644 --- a/src/v/cluster/metadata_dissemination_utils.cc +++ b/src/v/cluster/metadata_dissemination_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_dissemination_utils.h" diff --git a/src/v/cluster/metadata_dissemination_utils.h b/src/v/cluster/metadata_dissemination_utils.h index 28801d4c0d776..a23cf81be5622 100644 --- a/src/v/cluster/metadata_dissemination_utils.h +++ b/src/v/cluster/metadata_dissemination_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once diff --git a/src/v/cluster/namespace.h b/src/v/cluster/namespace.h index 78d922f78c6d8..e7920f3594e38 100644 --- a/src/v/cluster/namespace.h +++ b/src/v/cluster/namespace.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "seastarx.h" diff --git a/src/v/cluster/notification_latch.cc b/src/v/cluster/notification_latch.cc index dd7cb4b2b5b75..8b3e6fb8dc1cf 100644 --- a/src/v/cluster/notification_latch.cc +++ b/src/v/cluster/notification_latch.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/notification_latch.h" #include "utils/expiring_promise.h" diff --git a/src/v/cluster/notification_latch.h b/src/v/cluster/notification_latch.h index 3737e890a11d2..1932fc8c0ae0c 100644 --- a/src/v/cluster/notification_latch.h +++ b/src/v/cluster/notification_latch.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/errc.h" diff --git a/src/v/cluster/ntp_callbacks.h b/src/v/cluster/ntp_callbacks.h index 6c45d6ef30b70..2435bb6dde856 100644 --- a/src/v/cluster/ntp_callbacks.h +++ b/src/v/cluster/ntp_callbacks.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/partition.h" #include "cluster/types.h" diff --git a/src/v/cluster/partition.cc b/src/v/cluster/partition.cc index 9f3817e92eef4..1197ae3627515 100644 --- a/src/v/cluster/partition.cc +++ b/src/v/cluster/partition.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition.h" #include "cluster/logger.h" diff --git a/src/v/cluster/partition.h b/src/v/cluster/partition.h index 79b6d62fb0adc..fff4868afb727 100644 --- a/src/v/cluster/partition.h +++ b/src/v/cluster/partition.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/partition_probe.h" diff --git a/src/v/cluster/partition_allocator.cc b/src/v/cluster/partition_allocator.cc index 116d447716bb2..2424bbea001f6 100644 --- a/src/v/cluster/partition_allocator.cc +++ b/src/v/cluster/partition_allocator.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_allocator.h" #include "cluster/logger.h" diff --git a/src/v/cluster/partition_allocator.h b/src/v/cluster/partition_allocator.h index 5e1907628410e..8f9040e4988e5 100644 --- a/src/v/cluster/partition_allocator.h +++ b/src/v/cluster/partition_allocator.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/types.h" diff --git a/src/v/cluster/partition_leaders_table.cc b/src/v/cluster/partition_leaders_table.cc index 3a8ef1d491fd4..21f4a3b10966b 100644 --- a/src/v/cluster/partition_leaders_table.cc +++ b/src/v/cluster/partition_leaders_table.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_leaders_table.h" #include "model/fundamental.h" diff --git a/src/v/cluster/partition_leaders_table.h b/src/v/cluster/partition_leaders_table.h index aa41e6db57862..8542dc9c6825e 100644 --- a/src/v/cluster/partition_leaders_table.h +++ b/src/v/cluster/partition_leaders_table.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/cluster/partition_manager.cc b/src/v/cluster/partition_manager.cc index cc6c266366419..0bbd0a5ee6ae5 100644 --- a/src/v/cluster/partition_manager.cc +++ b/src/v/cluster/partition_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_manager.h" #include "cluster/logger.h" diff --git a/src/v/cluster/partition_manager.h b/src/v/cluster/partition_manager.h index 3a13238010856..8509e00416a4b 100644 --- a/src/v/cluster/partition_manager.h +++ b/src/v/cluster/partition_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/ntp_callbacks.h" diff --git a/src/v/cluster/partition_probe.cc b/src/v/cluster/partition_probe.cc index a9bb1c17a3b3e..cfd80937d92b2 100644 --- a/src/v/cluster/partition_probe.cc +++ b/src/v/cluster/partition_probe.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_probe.h" #include "cluster/partition.h" diff --git a/src/v/cluster/partition_probe.h b/src/v/cluster/partition_probe.h index 9d1910b1b5ec4..0b2c192ef10bd 100644 --- a/src/v/cluster/partition_probe.h +++ b/src/v/cluster/partition_probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/cluster/raft0_utils.h b/src/v/cluster/raft0_utils.h index 28b41c765217f..8b3cebe93cbae 100644 --- a/src/v/cluster/raft0_utils.h +++ b/src/v/cluster/raft0_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller_stm.h" diff --git a/src/v/cluster/service.cc b/src/v/cluster/service.cc index a889e6fc024fd..2d8ae554e0fdc 100644 --- a/src/v/cluster/service.cc +++ b/src/v/cluster/service.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/service.h" #include "cluster/members_manager.h" diff --git a/src/v/cluster/service.h b/src/v/cluster/service.h index 86504fc23e53d..0663ab7facaf0 100644 --- a/src/v/cluster/service.h +++ b/src/v/cluster/service.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller_service.h" #include "cluster/topics_frontend.h" diff --git a/src/v/cluster/shard_table.h b/src/v/cluster/shard_table.h index d053b760a337d..be407b61f6ebe 100644 --- a/src/v/cluster/shard_table.h +++ b/src/v/cluster/shard_table.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/cluster/simple_batch_builder.h b/src/v/cluster/simple_batch_builder.h index ff4058e92e265..57ac7b988a57f 100644 --- a/src/v/cluster/simple_batch_builder.h +++ b/src/v/cluster/simple_batch_builder.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/types.h" #include "reflection/adl.h" diff --git a/src/v/cluster/tests/allocation_bench.cc b/src/v/cluster/tests/allocation_bench.cc index 3080fbee477f1..a4485df2af9db 100644 --- a/src/v/cluster/tests/allocation_bench.cc +++ b/src/v/cluster/tests/allocation_bench.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/tests/partition_allocator_tester.h" #include "raft/types.h" diff --git a/src/v/cluster/tests/autocreate_test.cc b/src/v/cluster/tests/autocreate_test.cc index 5525716977c02..c5d43491f2635 100644 --- a/src/v/cluster/tests/autocreate_test.cc +++ b/src/v/cluster/tests/autocreate_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_cache.h" #include "cluster/simple_batch_builder.h" #include "cluster/tests/cluster_test_fixture.h" diff --git a/src/v/cluster/tests/cluster_test_fixture.h b/src/v/cluster/tests/cluster_test_fixture.h index aa81210d61419..6e062d7dcf166 100644 --- a/src/v/cluster/tests/cluster_test_fixture.h +++ b/src/v/cluster/tests/cluster_test_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller.h" #include "cluster/partition_manager.h" diff --git a/src/v/cluster/tests/cluster_tests.cc b/src/v/cluster/tests/cluster_tests.cc index 4c16ad3e2384e..0205094669d01 100644 --- a/src/v/cluster/tests/cluster_tests.cc +++ b/src/v/cluster/tests/cluster_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "cluster/tests/cluster_test_fixture.h" #include "test_utils/fixture.h" diff --git a/src/v/cluster/tests/cluster_utils_tests.cc b/src/v/cluster/tests/cluster_utils_tests.cc index 744013dc79367..8f1309ccfb8db 100644 --- a/src/v/cluster/tests/cluster_utils_tests.cc +++ b/src/v/cluster/tests/cluster_utils_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/cluster_utils.h" #include "cluster/types.h" #include "model/metadata.h" diff --git a/src/v/cluster/tests/commands_serialization_test.cc b/src/v/cluster/tests/commands_serialization_test.cc index 9208ec6bdeb61..06ebb6dad7f1b 100644 --- a/src/v/cluster/tests/commands_serialization_test.cc +++ b/src/v/cluster/tests/commands_serialization_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/commands.h" #include "cluster/partition_allocator.h" diff --git a/src/v/cluster/tests/configuration_change_test.cc b/src/v/cluster/tests/configuration_change_test.cc index 10a8217efc87e..1752b2167006b 100644 --- a/src/v/cluster/tests/configuration_change_test.cc +++ b/src/v/cluster/tests/configuration_change_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "cluster/tests/cluster_test_fixture.h" #include "cluster/tests/utils.h" diff --git a/src/v/cluster/tests/controller_recovery_test.cc b/src/v/cluster/tests/controller_recovery_test.cc index 7b59a1271554d..5d6391eda280a 100644 --- a/src/v/cluster/tests/controller_recovery_test.cc +++ b/src/v/cluster/tests/controller_recovery_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "cluster/tests/controller_test_fixture.h" #include "test_utils/fixture.h" diff --git a/src/v/cluster/tests/controller_state_test.cc b/src/v/cluster/tests/controller_state_test.cc index c11dff715d4e6..680ca2b1e4ce0 100644 --- a/src/v/cluster/tests/controller_state_test.cc +++ b/src/v/cluster/tests/controller_state_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "cluster/tests/cluster_test_fixture.h" #include "cluster/tests/utils.h" diff --git a/src/v/cluster/tests/controller_test_fixture.h b/src/v/cluster/tests/controller_test_fixture.h index 8701fcb32c767..d95a5f581a3e5 100644 --- a/src/v/cluster/tests/controller_test_fixture.h +++ b/src/v/cluster/tests/controller_test_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/commands.h" #include "cluster/controller.h" diff --git a/src/v/cluster/tests/metadata_dissemination_test.cc b/src/v/cluster/tests/metadata_dissemination_test.cc index a7907b1c49207..abc7b0ade1069 100644 --- a/src/v/cluster/tests/metadata_dissemination_test.cc +++ b/src/v/cluster/tests/metadata_dissemination_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/metadata_cache.h" #include "cluster/simple_batch_builder.h" diff --git a/src/v/cluster/tests/metadata_dissemination_utils_test.cc b/src/v/cluster/tests/metadata_dissemination_utils_test.cc index 77c5e18d322ea..3bcad5a95e62d 100644 --- a/src/v/cluster/tests/metadata_dissemination_utils_test.cc +++ b/src/v/cluster/tests/metadata_dissemination_utils_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include diff --git a/src/v/cluster/tests/notification_latch_test.cc b/src/v/cluster/tests/notification_latch_test.cc index 09da71d9a726f..dd09ab09a0728 100644 --- a/src/v/cluster/tests/notification_latch_test.cc +++ b/src/v/cluster/tests/notification_latch_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/errc.h" #include "cluster/notification_latch.h" #include "model/fundamental.h" diff --git a/src/v/cluster/tests/partition_allocator_tester.h b/src/v/cluster/tests/partition_allocator_tester.h index bc0b0304a59df..79fa0af7dc710 100644 --- a/src/v/cluster/tests/partition_allocator_tester.h +++ b/src/v/cluster/tests/partition_allocator_tester.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/partition_allocator.h" diff --git a/src/v/cluster/tests/partition_allocator_tests.cc b/src/v/cluster/tests/partition_allocator_tests.cc index 0ba20e2ad25a7..2c7ab09697590 100644 --- a/src/v/cluster/tests/partition_allocator_tests.cc +++ b/src/v/cluster/tests/partition_allocator_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_allocator.h" #include "cluster/tests/partition_allocator_tester.h" #include "raft/types.h" diff --git a/src/v/cluster/tests/partition_reassignment_test.cc b/src/v/cluster/tests/partition_reassignment_test.cc index 3ad71f44a7770..20709b8a99554 100644 --- a/src/v/cluster/tests/partition_reassignment_test.cc +++ b/src/v/cluster/tests/partition_reassignment_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition.h" #include "cluster/tests/cluster_test_fixture.h" #include "model/metadata.h" diff --git a/src/v/cluster/tests/serialization_rt_test.cc b/src/v/cluster/tests/serialization_rt_test.cc index 2a807da9081d5..a63501b578e53 100644 --- a/src/v/cluster/tests/serialization_rt_test.cc +++ b/src/v/cluster/tests/serialization_rt_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/tests/utils.h" #include "cluster/types.h" #include "model/compression.h" diff --git a/src/v/cluster/tests/simple_batch_builder_test.cc b/src/v/cluster/tests/simple_batch_builder_test.cc index 42571313210e4..6e6a96baa74f0 100644 --- a/src/v/cluster/tests/simple_batch_builder_test.cc +++ b/src/v/cluster/tests/simple_batch_builder_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "model/record_utils.h" #include "random/generators.h" diff --git a/src/v/cluster/tests/topic_table_fixture.h b/src/v/cluster/tests/topic_table_fixture.h index 8de49d30bf1b1..396a53d838f85 100644 --- a/src/v/cluster/tests/topic_table_fixture.h +++ b/src/v/cluster/tests/topic_table_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/tests/utils.h" diff --git a/src/v/cluster/tests/topic_table_test.cc b/src/v/cluster/tests/topic_table_test.cc index a40acfe772a5c..a832078c81dfe 100644 --- a/src/v/cluster/tests/topic_table_test.cc +++ b/src/v/cluster/tests/topic_table_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/tests/topic_table_fixture.h" #include "model/fundamental.h" diff --git a/src/v/cluster/tests/topic_updates_dispatcher_test.cc b/src/v/cluster/tests/topic_updates_dispatcher_test.cc index 5eb99cdcda6b3..928886d0d37a8 100644 --- a/src/v/cluster/tests/topic_updates_dispatcher_test.cc +++ b/src/v/cluster/tests/topic_updates_dispatcher_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/partition_allocator.h" #include "cluster/tests/topic_table_fixture.h" #include "cluster/topic_updates_dispatcher.h" diff --git a/src/v/cluster/tests/utils.h b/src/v/cluster/tests/utils.h index cf1ae1a6b761d..0d4c7a413c70d 100644 --- a/src/v/cluster/tests/utils.h +++ b/src/v/cluster/tests/utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/types.h" diff --git a/src/v/cluster/topic_table.cc b/src/v/cluster/topic_table.cc index 88b79ead953a2..ad25def4a931f 100644 --- a/src/v/cluster/topic_table.cc +++ b/src/v/cluster/topic_table.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/topic_table.h" diff --git a/src/v/cluster/topic_table.h b/src/v/cluster/topic_table.h index ca9993adfe52f..914250b3a4863 100644 --- a/src/v/cluster/topic_table.h +++ b/src/v/cluster/topic_table.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/commands.h" diff --git a/src/v/cluster/topic_updates_dispatcher.cc b/src/v/cluster/topic_updates_dispatcher.cc index f2e4d91dae2de..5a8997c3a1d12 100644 --- a/src/v/cluster/topic_updates_dispatcher.cc +++ b/src/v/cluster/topic_updates_dispatcher.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/topic_updates_dispatcher.h" #include "cluster/commands.h" diff --git a/src/v/cluster/topic_updates_dispatcher.h b/src/v/cluster/topic_updates_dispatcher.h index c31c8a88bc3a1..f8dc41a11a84e 100644 --- a/src/v/cluster/topic_updates_dispatcher.h +++ b/src/v/cluster/topic_updates_dispatcher.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/commands.h" #include "cluster/partition_allocator.h" diff --git a/src/v/cluster/topics_frontend.cc b/src/v/cluster/topics_frontend.cc index 5161bbda010a2..7ecc93ff6cdb5 100644 --- a/src/v/cluster/topics_frontend.cc +++ b/src/v/cluster/topics_frontend.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/topics_frontend.h" #include "cluster/cluster_utils.h" diff --git a/src/v/cluster/topics_frontend.h b/src/v/cluster/topics_frontend.h index 75100bd9ed1e6..4a43537453ce9 100644 --- a/src/v/cluster/topics_frontend.h +++ b/src/v/cluster/topics_frontend.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/commands.h" diff --git a/src/v/cluster/types.cc b/src/v/cluster/types.cc index d06b3b8a7ef0c..793e99f70c5b5 100644 --- a/src/v/cluster/types.cc +++ b/src/v/cluster/types.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/types.h" #include "model/fundamental.h" diff --git a/src/v/cluster/types.h b/src/v/cluster/types.h index 60e0579c941ef..628e7b10d3d87 100644 --- a/src/v/cluster/types.h +++ b/src/v/cluster/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/errc.h" diff --git a/src/v/compression/compression.cc b/src/v/compression/compression.cc index b7966c9765ef7..2ee32656250e5 100644 --- a/src/v/compression/compression.cc +++ b/src/v/compression/compression.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/compression.h" #include "compression/internal/gzip_compressor.h" diff --git a/src/v/compression/compression.h b/src/v/compression/compression.h index 098048df19480..a5be12fd22cdf 100644 --- a/src/v/compression/compression.h +++ b/src/v/compression/compression.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "model/compression.h" diff --git a/src/v/compression/internal/gzip_compressor.cc b/src/v/compression/internal/gzip_compressor.cc index dce95ce7f8844..1aef3113dd19c 100644 --- a/src/v/compression/internal/gzip_compressor.cc +++ b/src/v/compression/internal/gzip_compressor.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/internal/gzip_compressor.h" #include "bytes/bytes.h" diff --git a/src/v/compression/internal/gzip_compressor.h b/src/v/compression/internal/gzip_compressor.h index d4c0de064245f..e12c9f8e5d7d3 100644 --- a/src/v/compression/internal/gzip_compressor.h +++ b/src/v/compression/internal/gzip_compressor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" namespace compression::internal { diff --git a/src/v/compression/internal/lz4_frame_compressor.cc b/src/v/compression/internal/lz4_frame_compressor.cc index aa3304ac5b617..f59b5ae3c0e65 100644 --- a/src/v/compression/internal/lz4_frame_compressor.cc +++ b/src/v/compression/internal/lz4_frame_compressor.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/internal/lz4_frame_compressor.h" #include "bytes/bytes.h" diff --git a/src/v/compression/internal/lz4_frame_compressor.h b/src/v/compression/internal/lz4_frame_compressor.h index 5c005e8632822..bfb5f373fca66 100644 --- a/src/v/compression/internal/lz4_frame_compressor.h +++ b/src/v/compression/internal/lz4_frame_compressor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" namespace compression::internal { diff --git a/src/v/compression/internal/snappy_java_compressor.cc b/src/v/compression/internal/snappy_java_compressor.cc index 9b5f42ba81e4b..5e63a89fa099b 100644 --- a/src/v/compression/internal/snappy_java_compressor.cc +++ b/src/v/compression/internal/snappy_java_compressor.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/internal/snappy_java_compressor.h" #include "bytes/bytes.h" diff --git a/src/v/compression/internal/snappy_java_compressor.h b/src/v/compression/internal/snappy_java_compressor.h index 5911d797ce9a5..c1e8c64f41406 100644 --- a/src/v/compression/internal/snappy_java_compressor.h +++ b/src/v/compression/internal/snappy_java_compressor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/compression/internal/zstd_compressor.h b/src/v/compression/internal/zstd_compressor.h index 2df55f24db8b8..2169fde7f16f4 100644 --- a/src/v/compression/internal/zstd_compressor.h +++ b/src/v/compression/internal/zstd_compressor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "compression/stream_zstd.h" diff --git a/src/v/compression/logger.cc b/src/v/compression/logger.cc index ff9d1eb7e5f94..fa48b72d471cf 100644 --- a/src/v/compression/logger.cc +++ b/src/v/compression/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/logger.h" namespace compression { ss::logger complog{"compression"}; diff --git a/src/v/compression/logger.h b/src/v/compression/logger.h index 10c927436708e..116973d96462c 100644 --- a/src/v/compression/logger.h +++ b/src/v/compression/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/compression/snappy_standard_compressor.cc b/src/v/compression/snappy_standard_compressor.cc index 518eed1cc8ee1..f088ead1b93d1 100644 --- a/src/v/compression/snappy_standard_compressor.cc +++ b/src/v/compression/snappy_standard_compressor.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/snappy_standard_compressor.h" #include "bytes/bytes.h" diff --git a/src/v/compression/snappy_standard_compressor.h b/src/v/compression/snappy_standard_compressor.h index 8d9c3fe3ff811..3828ee1c91d42 100644 --- a/src/v/compression/snappy_standard_compressor.h +++ b/src/v/compression/snappy_standard_compressor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/compression/stream_zstd.cc b/src/v/compression/stream_zstd.cc index a761d45071923..daa247edaf02b 100644 --- a/src/v/compression/stream_zstd.cc +++ b/src/v/compression/stream_zstd.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/stream_zstd.h" #include "bytes/bytes.h" diff --git a/src/v/compression/stream_zstd.h b/src/v/compression/stream_zstd.h index 7368cff5a18bc..6d0c154a7cfc6 100644 --- a/src/v/compression/stream_zstd.h +++ b/src/v/compression/stream_zstd.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "static_deleter_fn.h" diff --git a/src/v/compression/tests/zstd_stream_bench.cc b/src/v/compression/tests/zstd_stream_bench.cc index c973cffe76251..a657abd6ade1f 100644 --- a/src/v/compression/tests/zstd_stream_bench.cc +++ b/src/v/compression/tests/zstd_stream_bench.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/stream_zstd.h" #include "random/generators.h" #include "vassert.h" diff --git a/src/v/compression/tests/zstd_tests.cc b/src/v/compression/tests/zstd_tests.cc index ba7fc0a5efe20..7c6f1331860e3 100644 --- a/src/v/compression/tests/zstd_tests.cc +++ b/src/v/compression/tests/zstd_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/internal/gzip_compressor.h" #include "compression/internal/lz4_frame_compressor.h" #include "compression/internal/snappy_java_compressor.h" diff --git a/src/v/config/base_property.cc b/src/v/config/base_property.cc index 68510f0bcd0c8..cd3d176f9ed17 100644 --- a/src/v/config/base_property.cc +++ b/src/v/config/base_property.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/base_property.h" #include "config/config_store.h" diff --git a/src/v/config/base_property.h b/src/v/config/base_property.h index c719e9e4e47cf..7858f70ee7ee3 100644 --- a/src/v/config/base_property.h +++ b/src/v/config/base_property.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/validation_error.h" #include "json/json.h" diff --git a/src/v/config/config_store.h b/src/v/config/config_store.h index 8e2ffde3ad50a..812231b0139a9 100644 --- a/src/v/config/config_store.h +++ b/src/v/config/config_store.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/property.h" diff --git a/src/v/config/configuration.cc b/src/v/config/configuration.cc index 1b2d859a2d4cd..5b0053ec07085 100644 --- a/src/v/config/configuration.cc +++ b/src/v/config/configuration.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/configuration.h" #include "units.h" diff --git a/src/v/config/configuration.h b/src/v/config/configuration.h index 9e334e7270ca1..3aa6af3758736 100644 --- a/src/v/config/configuration.h +++ b/src/v/config/configuration.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/config_store.h" #include "config/data_directory_path.h" diff --git a/src/v/config/data_directory_path.h b/src/v/config/data_directory_path.h index 8056347d07ed0..cbd14b77229dc 100644 --- a/src/v/config/data_directory_path.h +++ b/src/v/config/data_directory_path.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/config/property.h b/src/v/config/property.h index 403d45df44c92..240cbfac8d557 100644 --- a/src/v/config/property.h +++ b/src/v/config/property.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/base_property.h" #include "config/rjson_serialization.h" diff --git a/src/v/config/rjson_serialization.cc b/src/v/config/rjson_serialization.cc index e1eac40dfeaa8..bae0c83301a61 100644 --- a/src/v/config/rjson_serialization.cc +++ b/src/v/config/rjson_serialization.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/rjson_serialization.h" namespace json { diff --git a/src/v/config/rjson_serialization.h b/src/v/config/rjson_serialization.h index 7dba7a9ed278b..964def97807d7 100644 --- a/src/v/config/rjson_serialization.h +++ b/src/v/config/rjson_serialization.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/data_directory_path.h" diff --git a/src/v/config/seed_server.h b/src/v/config/seed_server.h index 6d4db1acc88ac..d240baf4712dd 100644 --- a/src/v/config/seed_server.h +++ b/src/v/config/seed_server.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/config/tests/advertised_kafka_api_test.cc b/src/v/config/tests/advertised_kafka_api_test.cc index cfc930ba2de3a..bade7f11fa6f0 100644 --- a/src/v/config/tests/advertised_kafka_api_test.cc +++ b/src/v/config/tests/advertised_kafka_api_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/configuration.h" #include diff --git a/src/v/config/tests/config_store_test.cc b/src/v/config/tests/config_store_test.cc index 361ad65b7caef..5da790c223c31 100644 --- a/src/v/config/tests/config_store_test.cc +++ b/src/v/config/tests/config_store_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/config_store.h" #include diff --git a/src/v/config/tests/custom_aggregate.h b/src/v/config/tests/custom_aggregate.h index 8c910aa631556..bf635d70369a6 100644 --- a/src/v/config/tests/custom_aggregate.h +++ b/src/v/config/tests/custom_aggregate.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/config/tests/socket_address_convert_test.cc b/src/v/config/tests/socket_address_convert_test.cc index fd795d8fd8edc..84261c988c51d 100644 --- a/src/v/config/tests/socket_address_convert_test.cc +++ b/src/v/config/tests/socket_address_convert_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/configuration.h" #include diff --git a/src/v/config/tests/tls_config_convert_test.cc b/src/v/config/tests/tls_config_convert_test.cc index 3fcac98abe52f..2029738315df6 100644 --- a/src/v/config/tests/tls_config_convert_test.cc +++ b/src/v/config/tests/tls_config_convert_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/configuration.h" #include "utils/to_string.h" diff --git a/src/v/config/tls_config.h b/src/v/config/tls_config.h index 2ca8166a4d8e4..e3389995b4b62 100644 --- a/src/v/config/tls_config.h +++ b/src/v/config/tls_config.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/config/validation_error.h b/src/v/config/validation_error.h index 115183ff39d60..e74110a026f44 100644 --- a/src/v/config/validation_error.h +++ b/src/v/config/validation_error.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/finjector/hbadger.cc b/src/v/finjector/hbadger.cc index 6654b29a47e0d..1be75ecdde230 100644 --- a/src/v/finjector/hbadger.cc +++ b/src/v/finjector/hbadger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "finjector/hbadger.h" #include "vlog.h" diff --git a/src/v/finjector/hbadger.h b/src/v/finjector/hbadger.h index d0c6631895443..d96bd15b134cf 100644 --- a/src/v/finjector/hbadger.h +++ b/src/v/finjector/hbadger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/hashing/crc32c.h b/src/v/hashing/crc32c.h index 905a1c8e2387a..7e10b5b603e8a 100644 --- a/src/v/hashing/crc32c.h +++ b/src/v/hashing/crc32c.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/hashing/fnv.h b/src/v/hashing/fnv.h index 03703d56b3f98..a00d5ed146379 100644 --- a/src/v/hashing/fnv.h +++ b/src/v/hashing/fnv.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include #include diff --git a/src/v/hashing/hash_bench.cc b/src/v/hashing/hash_bench.cc index f6887f785f42a..16d8750cea228 100644 --- a/src/v/hashing/hash_bench.cc +++ b/src/v/hashing/hash_bench.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "hashing/crc32c.h" #include "hashing/fnv.h" #include "hashing/twang.h" diff --git a/src/v/hashing/jenkins.h b/src/v/hashing/jenkins.h index 3384976fe2ace..ba570129f27f6 100644 --- a/src/v/hashing/jenkins.h +++ b/src/v/hashing/jenkins.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include /* diff --git a/src/v/hashing/jump_consistent_hash.h b/src/v/hashing/jump_consistent_hash.h index f01d50f8a3d60..e357f47727a83 100644 --- a/src/v/hashing/jump_consistent_hash.h +++ b/src/v/hashing/jump_consistent_hash.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/hashing/murmur.cc b/src/v/hashing/murmur.cc index 516e7e1e00e3b..fdbeeb3a26708 100644 --- a/src/v/hashing/murmur.cc +++ b/src/v/hashing/murmur.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "hashing/murmur.h" // adapted from original: diff --git a/src/v/hashing/murmur.h b/src/v/hashing/murmur.h index daeb1b43d6a80..752a0225d1e7d 100644 --- a/src/v/hashing/murmur.h +++ b/src/v/hashing/murmur.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/hashing/twang.h b/src/v/hashing/twang.h index 2babdf3a1a23a..debacdc5d2423 100644 --- a/src/v/hashing/twang.h +++ b/src/v/hashing/twang.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include /* diff --git a/src/v/hashing/xx.h b/src/v/hashing/xx.h index 6ef4130006108..aeabf342e134c 100644 --- a/src/v/hashing/xx.h +++ b/src/v/hashing/xx.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/hashing/xx_tests.cc b/src/v/hashing/xx_tests.cc index 14d5016416737..c1c58bb111221 100644 --- a/src/v/hashing/xx_tests.cc +++ b/src/v/hashing/xx_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE xxhash #include "hashing/xx.h" diff --git a/src/v/http/chunk_encoding.cc b/src/v/http/chunk_encoding.cc index 962519f5c2825..4dae24065078a 100644 --- a/src/v/http/chunk_encoding.cc +++ b/src/v/http/chunk_encoding.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/chunk_encoding.h" #include "bytes/iobuf.h" diff --git a/src/v/http/chunk_encoding.h b/src/v/http/chunk_encoding.h index 054320d196713..4e8f1b2cc0b2a 100644 --- a/src/v/http/chunk_encoding.h +++ b/src/v/http/chunk_encoding.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "seastarx.h" diff --git a/src/v/http/client.cc b/src/v/http/client.cc index cb530c70090b6..4aab000439509 100644 --- a/src/v/http/client.cc +++ b/src/v/http/client.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/client.h" #include diff --git a/src/v/http/client.h b/src/v/http/client.h index 98bb271b3a6b6..a6eae986468fa 100644 --- a/src/v/http/client.h +++ b/src/v/http/client.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/details/io_fragment.h" diff --git a/src/v/http/demo/client.cc b/src/v/http/demo/client.cc index 04cc0c2fac266..d3b007305e083 100644 --- a/src/v/http/demo/client.cc +++ b/src/v/http/demo/client.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/client.h" #include "rpc/transport.h" diff --git a/src/v/http/demo/echo.py b/src/v/http/demo/echo.py index 422c8b5174d95..9c41d4c012cf9 100644 --- a/src/v/http/demo/echo.py +++ b/src/v/http/demo/echo.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import cherrypy import json diff --git a/src/v/http/demo/run.sh b/src/v/http/demo/run.sh index 6af15df87aef1..e50036947b2f0 100755 --- a/src/v/http/demo/run.sh +++ b/src/v/http/demo/run.sh @@ -1,4 +1,13 @@ #!/bin/bash +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + if [[ ! -d "./src/v/http/demo" ]]; then echo "The script should be started from root v directory" exit 1 diff --git a/src/v/http/iobuf_body.cc b/src/v/http/iobuf_body.cc index c726e33130760..86c3f1f19bbed 100644 --- a/src/v/http/iobuf_body.cc +++ b/src/v/http/iobuf_body.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/iobuf_body.h" #include "http/logger.h" diff --git a/src/v/http/iobuf_body.h b/src/v/http/iobuf_body.h index a10019f6e3999..e177512aa53ea 100644 --- a/src/v/http/iobuf_body.h +++ b/src/v/http/iobuf_body.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/http/logger.cc b/src/v/http/logger.cc index b9ebd3a54499c..ac89b8dff69e5 100644 --- a/src/v/http/logger.cc +++ b/src/v/http/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/logger.h" namespace http { diff --git a/src/v/http/logger.h b/src/v/http/logger.h index c906590107bd7..40c07de0c8701 100644 --- a/src/v/http/logger.h +++ b/src/v/http/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/http/tests/framing_test.cc b/src/v/http/tests/framing_test.cc index 343dbd3500000..c15914ed9e5bf 100644 --- a/src/v/http/tests/framing_test.cc +++ b/src/v/http/tests/framing_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/details/io_byte_iterator.h" #include "bytes/details/io_fragment.h" #include "bytes/iobuf.h" diff --git a/src/v/http/tests/http_client_test.cc b/src/v/http/tests/http_client_test.cc index f6d1ccdc00dbb..27aea58194ed1 100644 --- a/src/v/http/tests/http_client_test.cc +++ b/src/v/http/tests/http_client_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "bytes/iobuf_parser.h" #include "http/chunk_encoding.h" diff --git a/src/v/json/json.cc b/src/v/json/json.cc index 0ea68c7245064..693051f33de48 100644 --- a/src/v/json/json.cc +++ b/src/v/json/json.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "json/json.h" namespace json { diff --git a/src/v/json/json.h b/src/v/json/json.h index abfa53b3467f6..62ecef6e15c19 100644 --- a/src/v/json/json.h +++ b/src/v/json/json.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/json/tests/json_serialization_test.cc b/src/v/json/tests/json_serialization_test.cc index 8a77f944956da..6926c83688f70 100644 --- a/src/v/json/tests/json_serialization_test.cc +++ b/src/v/json/tests/json_serialization_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "json/json.h" #include "seastarx.h" diff --git a/src/v/kafka/client.h b/src/v/kafka/client.h index 5fc6df7816129..94a3678e4799f 100644 --- a/src/v/kafka/client.h +++ b/src/v/kafka/client.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/protocol_utils.h" diff --git a/src/v/kafka/errors.cc b/src/v/kafka/errors.cc index aee8130f0092b..86bd34b453f1e 100644 --- a/src/v/kafka/errors.cc +++ b/src/v/kafka/errors.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/errors.h" #include diff --git a/src/v/kafka/errors.h b/src/v/kafka/errors.h index 3f27b0477ca8d..ccaf1abdf0735 100644 --- a/src/v/kafka/errors.h +++ b/src/v/kafka/errors.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/errc.h" diff --git a/src/v/kafka/groups/coordinator_ntp_mapper.h b/src/v/kafka/groups/coordinator_ntp_mapper.h index 033f1f3234bc4..e40449653f84d 100644 --- a/src/v/kafka/groups/coordinator_ntp_mapper.h +++ b/src/v/kafka/groups/coordinator_ntp_mapper.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/metadata_cache.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/groups/group.cc b/src/v/kafka/groups/group.cc index 9e6d901bb62d5..6cc2d0a552325 100644 --- a/src/v/kafka/groups/group.cc +++ b/src/v/kafka/groups/group.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/groups/group.h" #include "bytes/bytes.h" diff --git a/src/v/kafka/groups/group.h b/src/v/kafka/groups/group.h index 95cb94dc8334e..b0cacff1f295b 100644 --- a/src/v/kafka/groups/group.h +++ b/src/v/kafka/groups/group.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/partition.h" #include "config/configuration.h" diff --git a/src/v/kafka/groups/group_manager.cc b/src/v/kafka/groups/group_manager.cc index 79eceae6e3e29..58bbe07c3a259 100644 --- a/src/v/kafka/groups/group_manager.cc +++ b/src/v/kafka/groups/group_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/groups/group_manager.h" #include "cluster/simple_batch_builder.h" diff --git a/src/v/kafka/groups/group_manager.h b/src/v/kafka/groups/group_manager.h index 1914e66710c46..d2fb7318532f2 100644 --- a/src/v/kafka/groups/group_manager.h +++ b/src/v/kafka/groups/group_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/cluster_utils.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/groups/group_router.h b/src/v/kafka/groups/group_router.h index d1c43f4207a4d..eb5400bce78fd 100644 --- a/src/v/kafka/groups/group_router.h +++ b/src/v/kafka/groups/group_router.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/shard_table.h" #include "kafka/groups/coordinator_ntp_mapper.h" diff --git a/src/v/kafka/groups/member.cc b/src/v/kafka/groups/member.cc index bbe4590575854..039d8df3e6026 100644 --- a/src/v/kafka/groups/member.cc +++ b/src/v/kafka/groups/member.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + /** * TODO * - as noted below we should be tracking some statistics on real-world sizes diff --git a/src/v/kafka/groups/member.h b/src/v/kafka/groups/member.h index d016a28f04f57..22fbd0d81427e 100644 --- a/src/v/kafka/groups/member.h +++ b/src/v/kafka/groups/member.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" #include "bytes/iobuf.h" diff --git a/src/v/kafka/logger.cc b/src/v/kafka/logger.cc index 11f0cf448126b..2cb4006e12599 100644 --- a/src/v/kafka/logger.cc +++ b/src/v/kafka/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/logger.h" namespace kafka { diff --git a/src/v/kafka/logger.h b/src/v/kafka/logger.h index 92f5b2e3cde36..def0f75e0653d 100644 --- a/src/v/kafka/logger.h +++ b/src/v/kafka/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/kafka/protocol.cc b/src/v/kafka/protocol.cc index 8c77913c7db98..40676a93bd995 100644 --- a/src/v/kafka/protocol.cc +++ b/src/v/kafka/protocol.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "protocol.h" #include "cluster/topics_frontend.h" diff --git a/src/v/kafka/protocol.h b/src/v/kafka/protocol.h index d0d0cb5b6d35f..ade250c3f0eb5 100644 --- a/src/v/kafka/protocol.h +++ b/src/v/kafka/protocol.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/partition_manager.h" diff --git a/src/v/kafka/protocol_utils.cc b/src/v/kafka/protocol_utils.cc index 91907fcbd2273..fbd641d23f094 100644 --- a/src/v/kafka/protocol_utils.cc +++ b/src/v/kafka/protocol_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/protocol_utils.h" #include "bytes/iobuf.h" diff --git a/src/v/kafka/protocol_utils.h b/src/v/kafka/protocol_utils.h index 6e8f40391ed05..0d5b8070fd4c3 100644 --- a/src/v/kafka/protocol_utils.h +++ b/src/v/kafka/protocol_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/quota_manager.cc b/src/v/kafka/quota_manager.cc index 957bad1284654..6e2cc690add00 100644 --- a/src/v/kafka/quota_manager.cc +++ b/src/v/kafka/quota_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/quota_manager.h" #include "config/configuration.h" diff --git a/src/v/kafka/quota_manager.h b/src/v/kafka/quota_manager.h index cff0116111b10..bfe5e4842dcde 100644 --- a/src/v/kafka/quota_manager.h +++ b/src/v/kafka/quota_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/configuration.h" #include "resource_mgmt/rate.h" diff --git a/src/v/kafka/requests/alter_configs_request.cc b/src/v/kafka/requests/alter_configs_request.cc index 432ee833f51a0..379b277469b05 100644 --- a/src/v/kafka/requests/alter_configs_request.cc +++ b/src/v/kafka/requests/alter_configs_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/alter_configs_request.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/alter_configs_request.h b/src/v/kafka/requests/alter_configs_request.h index ed747d2ee3f0e..8703f6e235ff8 100644 --- a/src/v/kafka/requests/alter_configs_request.h +++ b/src/v/kafka/requests/alter_configs_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/api_versions_request.cc b/src/v/kafka/requests/api_versions_request.cc index b238e5656bc73..0ab86091ce030 100644 --- a/src/v/kafka/requests/api_versions_request.cc +++ b/src/v/kafka/requests/api_versions_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/api_versions_request.h" #include "kafka/requests/alter_configs_request.h" diff --git a/src/v/kafka/requests/api_versions_request.h b/src/v/kafka/requests/api_versions_request.h index cf611c76dcb23..3db021adb13f5 100644 --- a/src/v/kafka/requests/api_versions_request.h +++ b/src/v/kafka/requests/api_versions_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/batch_consumer.h b/src/v/kafka/requests/batch_consumer.h index bd71f32bbd34e..9161a286c27f2 100644 --- a/src/v/kafka/requests/batch_consumer.h +++ b/src/v/kafka/requests/batch_consumer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "kafka/requests/kafka_batch_adapter.h" diff --git a/src/v/kafka/requests/create_topics_request.cc b/src/v/kafka/requests/create_topics_request.cc index 549503a4bf847..53fd32bddfa5a 100644 --- a/src/v/kafka/requests/create_topics_request.cc +++ b/src/v/kafka/requests/create_topics_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/create_topics_request.h" #include "cluster/topics_frontend.h" diff --git a/src/v/kafka/requests/create_topics_request.h b/src/v/kafka/requests/create_topics_request.h index 21c7166c31806..6f4780c2d7a13 100644 --- a/src/v/kafka/requests/create_topics_request.h +++ b/src/v/kafka/requests/create_topics_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/delete_groups_request.h b/src/v/kafka/requests/delete_groups_request.h index ebd83e63b4376..f459a7d54d754 100644 --- a/src/v/kafka/requests/delete_groups_request.h +++ b/src/v/kafka/requests/delete_groups_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/requests/fwd.h" diff --git a/src/v/kafka/requests/delete_topics_request.cc b/src/v/kafka/requests/delete_topics_request.cc index d4ae6a01edc78..e0af0e418a842 100644 --- a/src/v/kafka/requests/delete_topics_request.cc +++ b/src/v/kafka/requests/delete_topics_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/delete_topics_request.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/requests/delete_topics_request.h b/src/v/kafka/requests/delete_topics_request.h index af73bbcb39f4b..60e2f1b4a5294 100644 --- a/src/v/kafka/requests/delete_topics_request.h +++ b/src/v/kafka/requests/delete_topics_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/kafka/requests/describe_configs_request.cc b/src/v/kafka/requests/describe_configs_request.cc index 004e0b7130b00..a0656d9d7fa52 100644 --- a/src/v/kafka/requests/describe_configs_request.cc +++ b/src/v/kafka/requests/describe_configs_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/describe_configs_request.h" #include "cluster/metadata_cache.h" diff --git a/src/v/kafka/requests/describe_configs_request.h b/src/v/kafka/requests/describe_configs_request.h index c61f68b4447c2..9858a13644054 100644 --- a/src/v/kafka/requests/describe_configs_request.h +++ b/src/v/kafka/requests/describe_configs_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/describe_groups_request.cc b/src/v/kafka/requests/describe_groups_request.cc index 6e4491fd871e4..bd40b43798b41 100644 --- a/src/v/kafka/requests/describe_groups_request.cc +++ b/src/v/kafka/requests/describe_groups_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/describe_groups_request.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/requests/describe_groups_request.h b/src/v/kafka/requests/describe_groups_request.h index 6c49c5d970580..5354d20599e99 100644 --- a/src/v/kafka/requests/describe_groups_request.h +++ b/src/v/kafka/requests/describe_groups_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/groups/group.h" diff --git a/src/v/kafka/requests/fetch_request.cc b/src/v/kafka/requests/fetch_request.cc index 0ef551d8bcc88..f7aa49d0ebc70 100644 --- a/src/v/kafka/requests/fetch_request.cc +++ b/src/v/kafka/requests/fetch_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/fetch_request.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/requests/fetch_request.h b/src/v/kafka/requests/fetch_request.h index 85892ee165d34..101bf7c746994 100644 --- a/src/v/kafka/requests/fetch_request.h +++ b/src/v/kafka/requests/fetch_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/find_coordinator_request.cc b/src/v/kafka/requests/find_coordinator_request.cc index 16a16f5119cba..e3d986488e102 100644 --- a/src/v/kafka/requests/find_coordinator_request.cc +++ b/src/v/kafka/requests/find_coordinator_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/find_coordinator_request.h" #include "cluster/topics_frontend.h" diff --git a/src/v/kafka/requests/find_coordinator_request.h b/src/v/kafka/requests/find_coordinator_request.h index 5b53415a89365..4b85759924d4c 100644 --- a/src/v/kafka/requests/find_coordinator_request.h +++ b/src/v/kafka/requests/find_coordinator_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/fwd.h b/src/v/kafka/requests/fwd.h index e09b2122b5539..3139c092d93f7 100644 --- a/src/v/kafka/requests/fwd.h +++ b/src/v/kafka/requests/fwd.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/kafka/requests/heartbeat_request.cc b/src/v/kafka/requests/heartbeat_request.cc index 913ffa999c043..e643aff844c2c 100644 --- a/src/v/kafka/requests/heartbeat_request.cc +++ b/src/v/kafka/requests/heartbeat_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/heartbeat_request.h" #include "kafka/groups/group_manager.h" diff --git a/src/v/kafka/requests/heartbeat_request.h b/src/v/kafka/requests/heartbeat_request.h index 0d97c0cf87e8c..3c99422a98026 100644 --- a/src/v/kafka/requests/heartbeat_request.h +++ b/src/v/kafka/requests/heartbeat_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/join_group_request.cc b/src/v/kafka/requests/join_group_request.cc index 22680c7d3e6b3..e3a9d305f0038 100644 --- a/src/v/kafka/requests/join_group_request.cc +++ b/src/v/kafka/requests/join_group_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/join_group_request.h" #include "kafka/groups/group_manager.h" diff --git a/src/v/kafka/requests/join_group_request.h b/src/v/kafka/requests/join_group_request.h index f902900f51c85..499cbe5b436f2 100644 --- a/src/v/kafka/requests/join_group_request.h +++ b/src/v/kafka/requests/join_group_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/kafka_batch_adapter.cc b/src/v/kafka/requests/kafka_batch_adapter.cc index f4c8ad63792a3..6d18e8ad3b28c 100644 --- a/src/v/kafka/requests/kafka_batch_adapter.cc +++ b/src/v/kafka/requests/kafka_batch_adapter.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/kafka_batch_adapter.h" #include "hashing/crc32c.h" diff --git a/src/v/kafka/requests/kafka_batch_adapter.h b/src/v/kafka/requests/kafka_batch_adapter.h index e6925bb9ed58b..a2b0d34a738a7 100644 --- a/src/v/kafka/requests/kafka_batch_adapter.h +++ b/src/v/kafka/requests/kafka_batch_adapter.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf_parser.h" diff --git a/src/v/kafka/requests/leave_group_request.cc b/src/v/kafka/requests/leave_group_request.cc index 856e7eb2e6d1d..4de7f9c4a5744 100644 --- a/src/v/kafka/requests/leave_group_request.cc +++ b/src/v/kafka/requests/leave_group_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/leave_group_request.h" #include "kafka/groups/group_manager.h" diff --git a/src/v/kafka/requests/leave_group_request.h b/src/v/kafka/requests/leave_group_request.h index 7b24915c51bdb..4c98cccbe50f0 100644 --- a/src/v/kafka/requests/leave_group_request.h +++ b/src/v/kafka/requests/leave_group_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/list_groups_request.cc b/src/v/kafka/requests/list_groups_request.cc index 8d3ad8db9e437..e349d38af8911 100644 --- a/src/v/kafka/requests/list_groups_request.cc +++ b/src/v/kafka/requests/list_groups_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/list_groups_request.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/list_groups_request.h b/src/v/kafka/requests/list_groups_request.h index 4fd0204844aae..ab05a6d716c75 100644 --- a/src/v/kafka/requests/list_groups_request.h +++ b/src/v/kafka/requests/list_groups_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" #include "kafka/requests/response.h" diff --git a/src/v/kafka/requests/list_offsets_request.cc b/src/v/kafka/requests/list_offsets_request.cc index c15b8986140ab..12eb9bb9a4908 100644 --- a/src/v/kafka/requests/list_offsets_request.cc +++ b/src/v/kafka/requests/list_offsets_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/list_offsets_request.h" #include "cluster/metadata_cache.h" diff --git a/src/v/kafka/requests/list_offsets_request.h b/src/v/kafka/requests/list_offsets_request.h index 921f54c54b9b0..cf2f1d134a0d1 100644 --- a/src/v/kafka/requests/list_offsets_request.h +++ b/src/v/kafka/requests/list_offsets_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/metadata_request.cc b/src/v/kafka/requests/metadata_request.cc index 540534b7a3cf6..c9865aea8684a 100644 --- a/src/v/kafka/requests/metadata_request.cc +++ b/src/v/kafka/requests/metadata_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/metadata_request.h" #include "cluster/metadata_cache.h" diff --git a/src/v/kafka/requests/metadata_request.h b/src/v/kafka/requests/metadata_request.h index 5b38a53e51567..a91e924b70eaf 100644 --- a/src/v/kafka/requests/metadata_request.h +++ b/src/v/kafka/requests/metadata_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/offset_commit_request.cc b/src/v/kafka/requests/offset_commit_request.cc index 2e86b271c8937..68e04a7a5bca4 100644 --- a/src/v/kafka/requests/offset_commit_request.cc +++ b/src/v/kafka/requests/offset_commit_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/offset_commit_request.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/requests/offset_commit_request.h b/src/v/kafka/requests/offset_commit_request.h index 1fdce15af031e..2736e36df39f6 100644 --- a/src/v/kafka/requests/offset_commit_request.h +++ b/src/v/kafka/requests/offset_commit_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/kafka/requests/offset_fetch_request.cc b/src/v/kafka/requests/offset_fetch_request.cc index c56b618cf716c..04919d35e46c2 100644 --- a/src/v/kafka/requests/offset_fetch_request.cc +++ b/src/v/kafka/requests/offset_fetch_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/offset_fetch_request.h" #include "kafka/errors.h" diff --git a/src/v/kafka/requests/offset_fetch_request.h b/src/v/kafka/requests/offset_fetch_request.h index 75816bdcf9b89..33dc93f64a8cd 100644 --- a/src/v/kafka/requests/offset_fetch_request.h +++ b/src/v/kafka/requests/offset_fetch_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/kafka/requests/produce_request.cc b/src/v/kafka/requests/produce_request.cc index 5261c3d8519b4..cc8bccd937eb1 100644 --- a/src/v/kafka/requests/produce_request.cc +++ b/src/v/kafka/requests/produce_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/produce_request.h" #include "bytes/iobuf.h" diff --git a/src/v/kafka/requests/produce_request.h b/src/v/kafka/requests/produce_request.h index ee9727e178b80..ca2febcbd99fb 100644 --- a/src/v/kafka/requests/produce_request.h +++ b/src/v/kafka/requests/produce_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" diff --git a/src/v/kafka/requests/request_context.h b/src/v/kafka/requests/request_context.h index 076e1a62161d0..648be5484a54f 100644 --- a/src/v/kafka/requests/request_context.h +++ b/src/v/kafka/requests/request_context.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "kafka/logger.h" diff --git a/src/v/kafka/requests/request_reader.h b/src/v/kafka/requests/request_reader.h index 08aa1a5e4ffe9..cee9afb55191f 100644 --- a/src/v/kafka/requests/request_reader.h +++ b/src/v/kafka/requests/request_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/kafka/requests/requests.cc b/src/v/kafka/requests/requests.cc index d06f1bee35cd2..1f2dc2a4d5be5 100644 --- a/src/v/kafka/requests/requests.cc +++ b/src/v/kafka/requests/requests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/requests.h" #include "kafka/requests/alter_configs_request.h" diff --git a/src/v/kafka/requests/requests.h b/src/v/kafka/requests/requests.h index f6e82bb19d128..bdf49d2fe5190 100644 --- a/src/v/kafka/requests/requests.h +++ b/src/v/kafka/requests/requests.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/response.h b/src/v/kafka/requests/response.h index fcc6af97d023f..352fac365c53e 100644 --- a/src/v/kafka/requests/response.h +++ b/src/v/kafka/requests/response.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/kafka/requests/response_writer.h b/src/v/kafka/requests/response_writer.h index 9d441d3c1ebbc..997eabc082b76 100644 --- a/src/v/kafka/requests/response_writer.h +++ b/src/v/kafka/requests/response_writer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/kafka/requests/response_writer_utils.h b/src/v/kafka/requests/response_writer_utils.h index c422c61d5b097..155544c0c025e 100644 --- a/src/v/kafka/requests/response_writer_utils.h +++ b/src/v/kafka/requests/response_writer_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/kafka_batch_adapter.h" #include "kafka/requests/response_writer.h" diff --git a/src/v/kafka/requests/schemata/generator.py b/src/v/kafka/requests/schemata/generator.py index 3d96737f97c1e..ec0fd82fb8d5f 100644 --- a/src/v/kafka/requests/schemata/generator.py +++ b/src/v/kafka/requests/schemata/generator.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # # Code generator for kafka messages # ================================= diff --git a/src/v/kafka/requests/sync_group_request.cc b/src/v/kafka/requests/sync_group_request.cc index b10fac9c978d9..5451da227dee9 100644 --- a/src/v/kafka/requests/sync_group_request.cc +++ b/src/v/kafka/requests/sync_group_request.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/sync_group_request.h" #include "kafka/groups/group_manager.h" diff --git a/src/v/kafka/requests/sync_group_request.h b/src/v/kafka/requests/sync_group_request.h index 60e3de0fdd5b3..92f590c8d742f 100644 --- a/src/v/kafka/requests/sync_group_request.h +++ b/src/v/kafka/requests/sync_group_request.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" #include "kafka/requests/request_context.h" diff --git a/src/v/kafka/requests/timeout.h b/src/v/kafka/requests/timeout.h index 37e8c5b70fb75..f6b776cc7c024 100644 --- a/src/v/kafka/requests/timeout.h +++ b/src/v/kafka/requests/timeout.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/timeout_clock.h" namespace kafka { diff --git a/src/v/kafka/requests/topics/topic_utils.cc b/src/v/kafka/requests/topics/topic_utils.cc index fd91afa12b8a9..e56ddd87e5e47 100644 --- a/src/v/kafka/requests/topics/topic_utils.cc +++ b/src/v/kafka/requests/topics/topic_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/topics/topic_utils.h" #include "cluster/errc.h" diff --git a/src/v/kafka/requests/topics/topic_utils.h b/src/v/kafka/requests/topics/topic_utils.h index 1c6ad4f733743..c33d606c87532 100644 --- a/src/v/kafka/requests/topics/topic_utils.h +++ b/src/v/kafka/requests/topics/topic_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/metadata_cache.h" #include "cluster/types.h" diff --git a/src/v/kafka/requests/topics/types.cc b/src/v/kafka/requests/topics/types.cc index 784f66c1027dc..4fcbff0118c20 100644 --- a/src/v/kafka/requests/topics/types.cc +++ b/src/v/kafka/requests/topics/types.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/topics/types.h" #include "cluster/namespace.h" diff --git a/src/v/kafka/requests/topics/types.h b/src/v/kafka/requests/topics/types.h index 0880cf3d25c27..0ad8c71c1777d 100644 --- a/src/v/kafka/requests/topics/types.h +++ b/src/v/kafka/requests/topics/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/namespace.h" #include "cluster/types.h" diff --git a/src/v/kafka/requests/topics/validators.h b/src/v/kafka/requests/topics/validators.h index 032545e808138..f77e3032de799 100644 --- a/src/v/kafka/requests/topics/validators.h +++ b/src/v/kafka/requests/topics/validators.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/schemata/create_topics_request.h" #include "kafka/requests/schemata/create_topics_response.h" diff --git a/src/v/kafka/tests/api_versions_test.cc b/src/v/kafka/tests/api_versions_test.cc index 53ef48975dbb8..b0efb3a9b2639 100644 --- a/src/v/kafka/tests/api_versions_test.cc +++ b/src/v/kafka/tests/api_versions_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/api_versions_request.h" #include "kafka/types.h" #include "redpanda/tests/fixture.h" diff --git a/src/v/kafka/tests/create_topics_test.cc b/src/v/kafka/tests/create_topics_test.cc index 9d4632986e3d3..eb359ed4a4c49 100644 --- a/src/v/kafka/tests/create_topics_test.cc +++ b/src/v/kafka/tests/create_topics_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/create_topics_request.h" #include "redpanda/tests/fixture.h" #include "resource_mgmt/io_priority.h" diff --git a/src/v/kafka/tests/delete_topics_test.cc b/src/v/kafka/tests/delete_topics_test.cc index a7b8b39eaa53d..317ea7214b9c2 100644 --- a/src/v/kafka/tests/delete_topics_test.cc +++ b/src/v/kafka/tests/delete_topics_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/errors.h" #include "kafka/requests/delete_topics_request.h" #include "kafka/requests/metadata_request.h" diff --git a/src/v/kafka/tests/error_mapping_test.cc b/src/v/kafka/tests/error_mapping_test.cc index 9ebaec30522d3..c40a3463058b0 100644 --- a/src/v/kafka/tests/error_mapping_test.cc +++ b/src/v/kafka/tests/error_mapping_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE utils #include "kafka/errors.h" diff --git a/src/v/kafka/tests/fetch_test.cc b/src/v/kafka/tests/fetch_test.cc index 7fb2b7e39b8fe..22553adf513dd 100644 --- a/src/v/kafka/tests/fetch_test.cc +++ b/src/v/kafka/tests/fetch_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/fetch_request.h" #include "model/fundamental.h" #include "redpanda/tests/fixture.h" diff --git a/src/v/kafka/tests/find_coordinator_test.cc b/src/v/kafka/tests/find_coordinator_test.cc index 97e9d00613511..f2ab4cd05dba9 100644 --- a/src/v/kafka/tests/find_coordinator_test.cc +++ b/src/v/kafka/tests/find_coordinator_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/find_coordinator_request.h" #include "redpanda/tests/fixture.h" #include "resource_mgmt/io_priority.h" diff --git a/src/v/kafka/tests/group_test.cc b/src/v/kafka/tests/group_test.cc index b1109f2e2f7c3..18d8da5edcd60 100644 --- a/src/v/kafka/tests/group_test.cc +++ b/src/v/kafka/tests/group_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "config/configuration.h" #include "kafka/groups/group.h" #include "utils/to_string.h" diff --git a/src/v/kafka/tests/list_offsets_test.cc b/src/v/kafka/tests/list_offsets_test.cc index fb8a1af4672a8..400c28fb2f216 100644 --- a/src/v/kafka/tests/list_offsets_test.cc +++ b/src/v/kafka/tests/list_offsets_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/list_offsets_request.h" #include "redpanda/tests/fixture.h" #include "resource_mgmt/io_priority.h" diff --git a/src/v/kafka/tests/member_test.cc b/src/v/kafka/tests/member_test.cc index f6e82f00d2328..7381d154b800f 100644 --- a/src/v/kafka/tests/member_test.cc +++ b/src/v/kafka/tests/member_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/groups/member.h" #include "kafka/types.h" #include "utils/to_string.h" diff --git a/src/v/kafka/tests/metadata_test.cc b/src/v/kafka/tests/metadata_test.cc index b66c3f0a8da5d..a7043ea38b88e 100644 --- a/src/v/kafka/tests/metadata_test.cc +++ b/src/v/kafka/tests/metadata_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "librdkafka/rdkafkacpp.h" #include "model/fundamental.h" #include "redpanda/tests/fixture.h" diff --git a/src/v/kafka/tests/offset_commit_test.cc b/src/v/kafka/tests/offset_commit_test.cc index 684877123207a..13c2525a06eb7 100644 --- a/src/v/kafka/tests/offset_commit_test.cc +++ b/src/v/kafka/tests/offset_commit_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/offset_commit_request.h" #include "redpanda/tests/fixture.h" #include "resource_mgmt/io_priority.h" diff --git a/src/v/kafka/tests/offset_fetch_test.cc b/src/v/kafka/tests/offset_fetch_test.cc index 7c22c3ed68f7d..7cdfae81df56b 100644 --- a/src/v/kafka/tests/offset_fetch_test.cc +++ b/src/v/kafka/tests/offset_fetch_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/offset_fetch_request.h" #include "redpanda/tests/fixture.h" #include "resource_mgmt/io_priority.h" diff --git a/src/v/kafka/tests/produce_consume_test.cc b/src/v/kafka/tests/produce_consume_test.cc index 2b23d02217f35..18a8bc587b981 100644 --- a/src/v/kafka/tests/produce_consume_test.cc +++ b/src/v/kafka/tests/produce_consume_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/client.h" #include "kafka/errors.h" #include "kafka/requests/fetch_request.h" diff --git a/src/v/kafka/tests/read_write_roundtrip_test.cc b/src/v/kafka/tests/read_write_roundtrip_test.cc index 708c35322bbb0..2331721f0086d 100644 --- a/src/v/kafka/tests/read_write_roundtrip_test.cc +++ b/src/v/kafka/tests/read_write_roundtrip_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/request_reader.h" #include "kafka/requests/response_writer.h" #include "random/generators.h" diff --git a/src/v/kafka/tests/request_parser_test.cc b/src/v/kafka/tests/request_parser_test.cc index 0826ae661efb0..f6796c217b7b4 100644 --- a/src/v/kafka/tests/request_parser_test.cc +++ b/src/v/kafka/tests/request_parser_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/fetch_request.h" #include "kafka/requests/metadata_request.h" #include "kafka/requests/produce_request.h" diff --git a/src/v/kafka/tests/timeouts_conversion_test.cc b/src/v/kafka/tests/timeouts_conversion_test.cc index 2bc134de4b837..4264dcaf17185 100644 --- a/src/v/kafka/tests/timeouts_conversion_test.cc +++ b/src/v/kafka/tests/timeouts_conversion_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE requests #include "kafka/requests/timeout.h" diff --git a/src/v/kafka/tests/topic_recreate_test.cc b/src/v/kafka/tests/topic_recreate_test.cc index cec044d85407a..3d7ab5a719298 100644 --- a/src/v/kafka/tests/topic_recreate_test.cc +++ b/src/v/kafka/tests/topic_recreate_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/errors.h" #include "kafka/requests/batch_consumer.h" #include "kafka/requests/delete_topics_request.h" diff --git a/src/v/kafka/tests/topic_utils_test.cc b/src/v/kafka/tests/topic_utils_test.cc index 8d9ebc836d2ea..2c4851539eab7 100644 --- a/src/v/kafka/tests/topic_utils_test.cc +++ b/src/v/kafka/tests/topic_utils_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/requests/schemata/create_topics_response.h" #define BOOST_TEST_MODULE utils #include "kafka/requests/topics/topic_utils.h" diff --git a/src/v/kafka/tests/types_conversion_tests.cc b/src/v/kafka/tests/types_conversion_tests.cc index 9271f19b238f1..45bee38c4df2e 100644 --- a/src/v/kafka/tests/types_conversion_tests.cc +++ b/src/v/kafka/tests/types_conversion_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/metadata.h" #define BOOST_TEST_MODULE utils diff --git a/src/v/kafka/types.h b/src/v/kafka/types.h index 96ca100e226fd..9b0b1c6bc6dc2 100644 --- a/src/v/kafka/types.h +++ b/src/v/kafka/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" #include "reflection/adl.h" diff --git a/src/v/likely.h b/src/v/likely.h index 720d8b09019d2..2441b0cf8e1ba 100644 --- a/src/v/likely.h +++ b/src/v/likely.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // https://godbolt.org/z/iRot_i diff --git a/src/v/model/adl_serde.cc b/src/v/model/adl_serde.cc index 617b517b38234..5e48321006001 100644 --- a/src/v/model/adl_serde.cc +++ b/src/v/model/adl_serde.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/adl_serde.h" #include "model/record.h" diff --git a/src/v/model/adl_serde.h b/src/v/model/adl_serde.h index 079e460198ffa..6074427d96bc3 100644 --- a/src/v/model/adl_serde.h +++ b/src/v/model/adl_serde.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/model/async_adl_serde.cc b/src/v/model/async_adl_serde.cc index bd152ed056018..47bdd7e50b7b3 100644 --- a/src/v/model/async_adl_serde.cc +++ b/src/v/model/async_adl_serde.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/async_adl_serde.h" #include "model/adl_serde.h" diff --git a/src/v/model/async_adl_serde.h b/src/v/model/async_adl_serde.h index 564c7d70d2fe0..a13339cd5f9b1 100644 --- a/src/v/model/async_adl_serde.h +++ b/src/v/model/async_adl_serde.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record_batch_reader.h" #include "reflection/async_adl.h" diff --git a/src/v/model/compression.h b/src/v/model/compression.h index e7314acde0ed7..acc821c5743bb 100644 --- a/src/v/model/compression.h +++ b/src/v/model/compression.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/model/errc.h b/src/v/model/errc.h index 101ebad1193d1..863ebb443b395 100644 --- a/src/v/model/errc.h +++ b/src/v/model/errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/model/fundamental.h b/src/v/model/fundamental.h index 29b933b98d09f..339e6f361ae9a 100644 --- a/src/v/model/fundamental.h +++ b/src/v/model/fundamental.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/model/limits.h b/src/v/model/limits.h index a3e863c254718..4a09288b6ebee 100644 --- a/src/v/model/limits.h +++ b/src/v/model/limits.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/model/metadata.h b/src/v/model/metadata.h index 47982da2a99dd..49dd83ee1da48 100644 --- a/src/v/model/metadata.h +++ b/src/v/model/metadata.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/model/model.cc b/src/v/model/model.cc index 752d9236effad..1e0dc901b6088 100644 --- a/src/v/model/model.cc +++ b/src/v/model/model.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "model/compression.h" #include "model/fundamental.h" diff --git a/src/v/model/record.h b/src/v/model/record.h index ddbab61f1111b..8527c1b5b53ac 100644 --- a/src/v/model/record.h +++ b/src/v/model/record.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/model/record_batch_reader.cc b/src/v/model/record_batch_reader.cc index dbcb89664745a..f1bf96e695151 100644 --- a/src/v/model/record_batch_reader.cc +++ b/src/v/model/record_batch_reader.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record_batch_reader.h" #include diff --git a/src/v/model/record_batch_reader.h b/src/v/model/record_batch_reader.h index 5bfe93846cb32..66103f323f6a7 100644 --- a/src/v/model/record_batch_reader.h +++ b/src/v/model/record_batch_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/model/record_batch_types.h b/src/v/model/record_batch_types.h index e4bf9d1a7b844..5733a3084c094 100644 --- a/src/v/model/record_batch_types.h +++ b/src/v/model/record_batch_types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "utils/named_type.h" diff --git a/src/v/model/record_utils.cc b/src/v/model/record_utils.cc index d1eab43fbbea2..5edadb24e3db0 100644 --- a/src/v/model/record_utils.cc +++ b/src/v/model/record_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record_utils.h" #include "bytes/utils.h" diff --git a/src/v/model/record_utils.h b/src/v/model/record_utils.h index bc36c8b1b2a78..c9d46593bbfc9 100644 --- a/src/v/model/record_utils.h +++ b/src/v/model/record_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf_parser.h" diff --git a/src/v/model/tests/compression_lexical_cast_test.cc b/src/v/model/tests/compression_lexical_cast_test.cc index 0c9aabdbc86a6..b866b5077629e 100644 --- a/src/v/model/tests/compression_lexical_cast_test.cc +++ b/src/v/model/tests/compression_lexical_cast_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record.h" #define BOOST_TEST_MODULE model #include "model/compression.h" diff --git a/src/v/model/tests/model_serialization_test.cc b/src/v/model/tests/model_serialization_test.cc index d91abd96d7fa3..fe6eb332fc87a 100644 --- a/src/v/model/tests/model_serialization_test.cc +++ b/src/v/model/tests/model_serialization_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/adl_serde.h" #include "model/fundamental.h" #include "model/metadata.h" diff --git a/src/v/model/tests/ntp_path_test.cc b/src/v/model/tests/ntp_path_test.cc index 2cb3857caf11a..b925a76499204 100644 --- a/src/v/model/tests/ntp_path_test.cc +++ b/src/v/model/tests/ntp_path_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE model #include "model/fundamental.h" diff --git a/src/v/model/tests/record_batch_reader_test.cc b/src/v/model/tests/record_batch_reader_test.cc index ad8446c5195e5..15b935aef6e21 100644 --- a/src/v/model/tests/record_batch_reader_test.cc +++ b/src/v/model/tests/record_batch_reader_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record.h" #include "model/record_batch_reader.h" #include "storage/tests/utils/random_batch.h" diff --git a/src/v/model/tests/record_batch_test.cc b/src/v/model/tests/record_batch_test.cc index a46a37c2dd97c..397b91c083581 100644 --- a/src/v/model/tests/record_batch_test.cc +++ b/src/v/model/tests/record_batch_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record.h" #include "model/record_utils.h" #include "model/timestamp.h" diff --git a/src/v/model/tests/topic_view_tests.cc b/src/v/model/tests/topic_view_tests.cc index 2a67dcce64732..59ff977cd2f14 100644 --- a/src/v/model/tests/topic_view_tests.cc +++ b/src/v/model/tests/topic_view_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE model #include "model/fundamental.h" diff --git a/src/v/model/timeout_clock.h b/src/v/model/timeout_clock.h index 1e63b2cf89d02..32babf3402745 100644 --- a/src/v/model/timeout_clock.h +++ b/src/v/model/timeout_clock.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/model/timestamp.h b/src/v/model/timestamp.h index ea384369b3c45..72eee7631d107 100644 --- a/src/v/model/timestamp.h +++ b/src/v/model/timestamp.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/model/validation.cc b/src/v/model/validation.cc index b430e8d93987f..36f075fa9c1e0 100644 --- a/src/v/model/validation.cc +++ b/src/v/model/validation.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/validation.h" #include "model/errc.h" diff --git a/src/v/model/validation.h b/src/v/model/validation.h index 1c08165126f64..ea0ad444117cc 100644 --- a/src/v/model/validation.h +++ b/src/v/model/validation.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/oncore.h b/src/v/oncore.h index 85d872117da00..f70b1632051f1 100644 --- a/src/v/oncore.h +++ b/src/v/oncore.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #ifndef NDEBUG diff --git a/src/v/outcome.h b/src/v/outcome.h index 8b63ebcbe8344..c5a01a81b0ada 100644 --- a/src/v/outcome.h +++ b/src/v/outcome.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include // bring in std::error_code et al diff --git a/src/v/outcome_future_utils.h b/src/v/outcome_future_utils.h index 7ea9461af1f7e..7f6416227b475 100644 --- a/src/v/outcome_future_utils.h +++ b/src/v/outcome_future_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" diff --git a/src/v/outcome_tests.cc b/src/v/outcome_tests.cc index 2caffc9232b4e..6940cbd41fcde 100644 --- a/src/v/outcome_tests.cc +++ b/src/v/outcome_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE outcome #include "outcome.h" diff --git a/src/v/pandaproxy/application.cc b/src/v/pandaproxy/application.cc index 644601900da03..666fa0031d704 100644 --- a/src/v/pandaproxy/application.cc +++ b/src/v/pandaproxy/application.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/application.h" #include "pandaproxy/client/configuration.h" diff --git a/src/v/pandaproxy/application.h b/src/v/pandaproxy/application.h index 13fab50a2f17e..26fb035b0d943 100644 --- a/src/v/pandaproxy/application.h +++ b/src/v/pandaproxy/application.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/admin/api-doc/config.json.h" diff --git a/src/v/pandaproxy/client/broker.cc b/src/v/pandaproxy/client/broker.cc index aa90e7e325ed7..39aace09e6ae4 100644 --- a/src/v/pandaproxy/client/broker.cc +++ b/src/v/pandaproxy/client/broker.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/broker.h" #include "pandaproxy/client/logger.h" diff --git a/src/v/pandaproxy/client/broker.h b/src/v/pandaproxy/client/broker.h index 7d1d5b1b1b337..31e54afa2c0b3 100644 --- a/src/v/pandaproxy/client/broker.h +++ b/src/v/pandaproxy/client/broker.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/client.h" diff --git a/src/v/pandaproxy/client/brokers.cc b/src/v/pandaproxy/client/brokers.cc index 42cb9b9209749..2d892a465e552 100644 --- a/src/v/pandaproxy/client/brokers.cc +++ b/src/v/pandaproxy/client/brokers.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/brokers.h" #include "ssx/future-util.h" diff --git a/src/v/pandaproxy/client/brokers.h b/src/v/pandaproxy/client/brokers.h index f40c8d9b57ae6..d26422d61d0cc 100644 --- a/src/v/pandaproxy/client/brokers.h +++ b/src/v/pandaproxy/client/brokers.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/pandaproxy/client/client.cc b/src/v/pandaproxy/client/client.cc index 7823af8e0d701..12a9c01985017 100644 --- a/src/v/pandaproxy/client/client.cc +++ b/src/v/pandaproxy/client/client.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/client.h" #include "pandaproxy/client/broker.h" diff --git a/src/v/pandaproxy/client/client.h b/src/v/pandaproxy/client/client.h index 2fb0cc234559f..8e179f8354001 100644 --- a/src/v/pandaproxy/client/client.h +++ b/src/v/pandaproxy/client/client.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/client.h" diff --git a/src/v/pandaproxy/client/configuration.cc b/src/v/pandaproxy/client/configuration.cc index 68bb61c95b7f9..973f11b0b5ecf 100644 --- a/src/v/pandaproxy/client/configuration.cc +++ b/src/v/pandaproxy/client/configuration.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "configuration.h" #include "units.h" diff --git a/src/v/pandaproxy/client/configuration.h b/src/v/pandaproxy/client/configuration.h index d4384838a3700..767dea7f072d2 100644 --- a/src/v/pandaproxy/client/configuration.h +++ b/src/v/pandaproxy/client/configuration.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/config_store.h" #include "config/configuration.h" diff --git a/src/v/pandaproxy/client/error.h b/src/v/pandaproxy/client/error.h index b05e5aded7dac..c4a3dc1ac95a8 100644 --- a/src/v/pandaproxy/client/error.h +++ b/src/v/pandaproxy/client/error.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/errors.h" diff --git a/src/v/pandaproxy/client/logger.cc b/src/v/pandaproxy/client/logger.cc index 219d5feb1719e..f842c6c1b39ff 100644 --- a/src/v/pandaproxy/client/logger.cc +++ b/src/v/pandaproxy/client/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/logger.h" namespace pandaproxy::client { diff --git a/src/v/pandaproxy/client/logger.h b/src/v/pandaproxy/client/logger.h index bb220eb810dca..1db62cd66ca2d 100644 --- a/src/v/pandaproxy/client/logger.h +++ b/src/v/pandaproxy/client/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/pandaproxy/client/produce_batcher.h b/src/v/pandaproxy/client/produce_batcher.h index 853af04bd7d85..afb9d77e52f4e 100644 --- a/src/v/pandaproxy/client/produce_batcher.h +++ b/src/v/pandaproxy/client/produce_batcher.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/produce_request.h" diff --git a/src/v/pandaproxy/client/produce_partition.h b/src/v/pandaproxy/client/produce_partition.h index 8c77ff71bf29d..8c09a8308a5af 100644 --- a/src/v/pandaproxy/client/produce_partition.h +++ b/src/v/pandaproxy/client/produce_partition.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/pandaproxy/client/producer.cc b/src/v/pandaproxy/client/producer.cc index 1fe83e37ce3c0..5cadf99868222 100644 --- a/src/v/pandaproxy/client/producer.cc +++ b/src/v/pandaproxy/client/producer.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/producer.h" #include "kafka/errors.h" diff --git a/src/v/pandaproxy/client/producer.h b/src/v/pandaproxy/client/producer.h index 46fe84020b6cf..a468538ed204e 100644 --- a/src/v/pandaproxy/client/producer.h +++ b/src/v/pandaproxy/client/producer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/pandaproxy/client/retry_with_mitigation.h b/src/v/pandaproxy/client/retry_with_mitigation.h index 1d5f9f83e3025..89cf5f882c39b 100644 --- a/src/v/pandaproxy/client/retry_with_mitigation.h +++ b/src/v/pandaproxy/client/retry_with_mitigation.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "utils/concepts-enabled.h" diff --git a/src/v/pandaproxy/client/test/pandaproxy_client_fixture.h b/src/v/pandaproxy/client/test/pandaproxy_client_fixture.h index bbe4b495a4f0d..448f90339f8c6 100644 --- a/src/v/pandaproxy/client/test/pandaproxy_client_fixture.h +++ b/src/v/pandaproxy/client/test/pandaproxy_client_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "kafka/requests/metadata_request.h" diff --git a/src/v/pandaproxy/client/test/produce.cc b/src/v/pandaproxy/client/test/produce.cc index 0bf53d75246e7..5b259f4cbc043 100644 --- a/src/v/pandaproxy/client/test/produce.cc +++ b/src/v/pandaproxy/client/test/produce.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/errors.h" #include "kafka/requests/metadata_request.h" #include "kafka/requests/produce_request.h" diff --git a/src/v/pandaproxy/client/test/produce_batcher.cc b/src/v/pandaproxy/client/test/produce_batcher.cc index e290ac4f077c5..79eeff1d9444e 100644 --- a/src/v/pandaproxy/client/test/produce_batcher.cc +++ b/src/v/pandaproxy/client/test/produce_batcher.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/produce_batcher.h" #include "cluster/simple_batch_builder.h" diff --git a/src/v/pandaproxy/client/test/produce_partition.cc b/src/v/pandaproxy/client/test/produce_partition.cc index bbabed9199133..1259d997e79ba 100644 --- a/src/v/pandaproxy/client/test/produce_partition.cc +++ b/src/v/pandaproxy/client/test/produce_partition.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/produce_partition.h" #include "kafka/errors.h" diff --git a/src/v/pandaproxy/client/test/reconnect.cc b/src/v/pandaproxy/client/test/reconnect.cc index 2ebd0661182cf..680f09c201c3c 100644 --- a/src/v/pandaproxy/client/test/reconnect.cc +++ b/src/v/pandaproxy/client/test/reconnect.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "kafka/errors.h" #include "kafka/requests/metadata_request.h" #include "kafka/requests/produce_request.h" diff --git a/src/v/pandaproxy/client/test/retry_with_mitigation.cc b/src/v/pandaproxy/client/test/retry_with_mitigation.cc index 213a016897d91..d9332ce698ab0 100644 --- a/src/v/pandaproxy/client/test/retry_with_mitigation.cc +++ b/src/v/pandaproxy/client/test/retry_with_mitigation.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/client/retry_with_mitigation.h" #include diff --git a/src/v/pandaproxy/client/test/utils.h b/src/v/pandaproxy/client/test/utils.h index b47cc1efb2dbd..978b405240f55 100644 --- a/src/v/pandaproxy/client/test/utils.h +++ b/src/v/pandaproxy/client/test/utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/types.h" diff --git a/src/v/pandaproxy/configuration.cc b/src/v/pandaproxy/configuration.cc index 9b87a7381d7aa..48dea62393cbd 100644 --- a/src/v/pandaproxy/configuration.cc +++ b/src/v/pandaproxy/configuration.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "configuration.h" #include "units.h" diff --git a/src/v/pandaproxy/configuration.h b/src/v/pandaproxy/configuration.h index cd96b1f129f32..becc8d8c9dba9 100644 --- a/src/v/pandaproxy/configuration.h +++ b/src/v/pandaproxy/configuration.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/config_store.h" #include "config/configuration.h" diff --git a/src/v/pandaproxy/context.h b/src/v/pandaproxy/context.h index 95b33646e1227..918c472e7f657 100644 --- a/src/v/pandaproxy/context.h +++ b/src/v/pandaproxy/context.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/client/client.h" diff --git a/src/v/pandaproxy/handlers.cc b/src/v/pandaproxy/handlers.cc index f6421ac5653b7..1e34e9607fbd3 100644 --- a/src/v/pandaproxy/handlers.cc +++ b/src/v/pandaproxy/handlers.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "handlers.h" #include "pandaproxy/json/requests/produce.h" diff --git a/src/v/pandaproxy/handlers.h b/src/v/pandaproxy/handlers.h index 7e4159a5b5b84..ccce9edf2e883 100644 --- a/src/v/pandaproxy/handlers.h +++ b/src/v/pandaproxy/handlers.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/server.h" diff --git a/src/v/pandaproxy/json/iobuf.h b/src/v/pandaproxy/json/iobuf.h index 90f50021becb8..0c14758eeadac 100644 --- a/src/v/pandaproxy/json/iobuf.h +++ b/src/v/pandaproxy/json/iobuf.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/pandaproxy/json/requests/error_reply.h b/src/v/pandaproxy/json/requests/error_reply.h index ba1385ccff9f1..2d50d86500a31 100644 --- a/src/v/pandaproxy/json/requests/error_reply.h +++ b/src/v/pandaproxy/json/requests/error_reply.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "json/json.h" diff --git a/src/v/pandaproxy/json/requests/produce.h b/src/v/pandaproxy/json/requests/produce.h index cccbdfc913c56..ba0a25e949b45 100644 --- a/src/v/pandaproxy/json/requests/produce.h +++ b/src/v/pandaproxy/json/requests/produce.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/pandaproxy/json/requests/test/produce.cc b/src/v/pandaproxy/json/requests/test/produce.cc index a351e03dfa0ac..44eced2c28332 100644 --- a/src/v/pandaproxy/json/requests/test/produce.cc +++ b/src/v/pandaproxy/json/requests/test/produce.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/json/requests/produce.h" #include "kafka/requests/produce_request.h" diff --git a/src/v/pandaproxy/json/rjson_util.h b/src/v/pandaproxy/json/rjson_util.h index 6e6d60dd364cd..96a3f4e24da82 100644 --- a/src/v/pandaproxy/json/rjson_util.h +++ b/src/v/pandaproxy/json/rjson_util.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "json/json.h" diff --git a/src/v/pandaproxy/json/test/iobuf.cc b/src/v/pandaproxy/json/test/iobuf.cc index 3dccc8d6d78b1..6e1362a7f3faa 100644 --- a/src/v/pandaproxy/json/test/iobuf.cc +++ b/src/v/pandaproxy/json/test/iobuf.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/json/iobuf.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/pandaproxy/json/types.h b/src/v/pandaproxy/json/types.h index efeb3361e9f22..d24bd10da32b0 100644 --- a/src/v/pandaproxy/json/types.h +++ b/src/v/pandaproxy/json/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once namespace pandaproxy::json { diff --git a/src/v/pandaproxy/logger.cc b/src/v/pandaproxy/logger.cc index a90d0a177b658..3d4c8f9fef404 100644 --- a/src/v/pandaproxy/logger.cc +++ b/src/v/pandaproxy/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/logger.h" namespace pandaproxy { diff --git a/src/v/pandaproxy/logger.h b/src/v/pandaproxy/logger.h index 5cbc4ae813416..c4dd665f64183 100644 --- a/src/v/pandaproxy/logger.h +++ b/src/v/pandaproxy/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/pandaproxy/main.cc b/src/v/pandaproxy/main.cc index 1cda7435ffa0e..39a6a60de23ef 100644 --- a/src/v/pandaproxy/main.cc +++ b/src/v/pandaproxy/main.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/application.h" #include "syschecks/syschecks.h" diff --git a/src/v/pandaproxy/probe.cc b/src/v/pandaproxy/probe.cc index 7253e325b153a..ca7fc19eeecd6 100644 --- a/src/v/pandaproxy/probe.cc +++ b/src/v/pandaproxy/probe.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/probe.h" #include "prometheus/prometheus_sanitize.h" diff --git a/src/v/pandaproxy/probe.h b/src/v/pandaproxy/probe.h index 37ea2c060924c..65da51ccebe6e 100644 --- a/src/v/pandaproxy/probe.h +++ b/src/v/pandaproxy/probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "utils/hdr_hist.h" diff --git a/src/v/pandaproxy/proxy.cc b/src/v/pandaproxy/proxy.cc index 088b74aa03bdb..b7a71e2525bd8 100644 --- a/src/v/pandaproxy/proxy.cc +++ b/src/v/pandaproxy/proxy.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/proxy.h" #include "pandaproxy/api/api-doc/get_topics_names.json.h" diff --git a/src/v/pandaproxy/proxy.h b/src/v/pandaproxy/proxy.h index 5c60de1e2813d..8b0752cc3cead 100644 --- a/src/v/pandaproxy/proxy.h +++ b/src/v/pandaproxy/proxy.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/client/client.h" diff --git a/src/v/pandaproxy/reply.h b/src/v/pandaproxy/reply.h index 33852fa305376..eba8314fff98b 100644 --- a/src/v/pandaproxy/reply.h +++ b/src/v/pandaproxy/reply.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/json/requests/error_reply.h" diff --git a/src/v/pandaproxy/server.cc b/src/v/pandaproxy/server.cc index 03e668b6f58b3..e7caee9ce7942 100644 --- a/src/v/pandaproxy/server.cc +++ b/src/v/pandaproxy/server.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "pandaproxy/server.h" #include "pandaproxy/logger.h" diff --git a/src/v/pandaproxy/server.h b/src/v/pandaproxy/server.h index 2a5331fff5974..69f9552fa0d5d 100644 --- a/src/v/pandaproxy/server.h +++ b/src/v/pandaproxy/server.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "pandaproxy/context.h" diff --git a/src/v/pandaproxy/test/list_topics.cc b/src/v/pandaproxy/test/list_topics.cc index 030f91c33cbcc..1942ac71fdc10 100644 --- a/src/v/pandaproxy/test/list_topics.cc +++ b/src/v/pandaproxy/test/list_topics.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/client.h" #include "pandaproxy/test/pandaproxy_fixture.h" #include "pandaproxy/test/utils.h" diff --git a/src/v/pandaproxy/test/pandaproxy_fixture.h b/src/v/pandaproxy/test/pandaproxy_fixture.h index 73559bf59cb6a..84c81ca9061b2 100644 --- a/src/v/pandaproxy/test/pandaproxy_fixture.h +++ b/src/v/pandaproxy/test/pandaproxy_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/configuration.h" diff --git a/src/v/pandaproxy/test/produce.cc b/src/v/pandaproxy/test/produce.cc index a91cb6aa8cf60..c2dec3c5493c1 100644 --- a/src/v/pandaproxy/test/produce.cc +++ b/src/v/pandaproxy/test/produce.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "http/client.h" #include "pandaproxy/configuration.h" #include "pandaproxy/test/pandaproxy_fixture.h" diff --git a/src/v/pandaproxy/test/utils.h b/src/v/pandaproxy/test/utils.h index 86ae19dfee285..91ae39d457aac 100644 --- a/src/v/pandaproxy/test/utils.h +++ b/src/v/pandaproxy/test/utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/pandaproxy/types.h b/src/v/pandaproxy/types.h index a3ceab4b3dcd0..3e3df5dba1275 100644 --- a/src/v/pandaproxy/types.h +++ b/src/v/pandaproxy/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/platform/stop_signal.h b/src/v/platform/stop_signal.h index dd5f3e52b65b3..ac65ef360eb40 100644 --- a/src/v/platform/stop_signal.h +++ b/src/v/platform/stop_signal.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/prometheus/prometheus_sanitize.h b/src/v/prometheus/prometheus_sanitize.h index b134e0afcaab8..6a8f78921aa3f 100644 --- a/src/v/prometheus/prometheus_sanitize.h +++ b/src/v/prometheus/prometheus_sanitize.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/raft/configuration.cc b/src/v/raft/configuration.cc index 0ecbdb31c6b22..8a14df36bd0bc 100644 --- a/src/v/raft/configuration.cc +++ b/src/v/raft/configuration.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/configuration.h" #include "model/metadata.h" diff --git a/src/v/raft/configuration.h b/src/v/raft/configuration.h index 6762c6cdfe444..0a671993778cb 100644 --- a/src/v/raft/configuration.h +++ b/src/v/raft/configuration.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" #include "reflection/adl.h" diff --git a/src/v/raft/configuration_bootstrap_state.cc b/src/v/raft/configuration_bootstrap_state.cc index 44fc3abd8da78..bb104e0893d7b 100644 --- a/src/v/raft/configuration_bootstrap_state.cc +++ b/src/v/raft/configuration_bootstrap_state.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/configuration_bootstrap_state.h" #include "likely.h" diff --git a/src/v/raft/configuration_bootstrap_state.h b/src/v/raft/configuration_bootstrap_state.h index ba2115c636ea7..e21f6f27f1f1a 100644 --- a/src/v/raft/configuration_bootstrap_state.h +++ b/src/v/raft/configuration_bootstrap_state.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/types.h" diff --git a/src/v/raft/configuration_manager.cc b/src/v/raft/configuration_manager.cc index cc848d56c27c5..7fdbe0362f57c 100644 --- a/src/v/raft/configuration_manager.cc +++ b/src/v/raft/configuration_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/configuration_manager.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/raft/configuration_manager.h b/src/v/raft/configuration_manager.h index dc3446af8df23..8fcb67aeadc4d 100644 --- a/src/v/raft/configuration_manager.h +++ b/src/v/raft/configuration_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/raft/consensus.cc b/src/v/raft/consensus.cc index 630857728b260..74bd863e12b29 100644 --- a/src/v/raft/consensus.cc +++ b/src/v/raft/consensus.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/consensus.h" #include "config/configuration.h" diff --git a/src/v/raft/consensus.h b/src/v/raft/consensus.h index adbd82b28b9a7..ca31a5a31019c 100644 --- a/src/v/raft/consensus.h +++ b/src/v/raft/consensus.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "hashing/crc32c.h" diff --git a/src/v/raft/consensus_client_protocol.h b/src/v/raft/consensus_client_protocol.h index 9326184cf5ae4..d1cd8f40ba790 100644 --- a/src/v/raft/consensus_client_protocol.h +++ b/src/v/raft/consensus_client_protocol.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" #include "model/timeout_clock.h" diff --git a/src/v/raft/consensus_utils.cc b/src/v/raft/consensus_utils.cc index 7d4097863a9f0..30c73fb4749e7 100644 --- a/src/v/raft/consensus_utils.cc +++ b/src/v/raft/consensus_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/consensus_utils.h" #include "likely.h" diff --git a/src/v/raft/consensus_utils.h b/src/v/raft/consensus_utils.h index 8a9962809a0a3..589cefc8f3097 100644 --- a/src/v/raft/consensus_utils.h +++ b/src/v/raft/consensus_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/raft/errc.h b/src/v/raft/errc.h index 519f24db46dd5..2478fe63b6c5e 100644 --- a/src/v/raft/errc.h +++ b/src/v/raft/errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/raft/event_manager.cc b/src/v/raft/event_manager.cc index d10daaaaa74ce..533a00a24af82 100644 --- a/src/v/raft/event_manager.cc +++ b/src/v/raft/event_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/event_manager.h" #include "raft/consensus.h" diff --git a/src/v/raft/event_manager.h b/src/v/raft/event_manager.h index b57a57e261f81..88fd3eb0658f6 100644 --- a/src/v/raft/event_manager.h +++ b/src/v/raft/event_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "raft/offset_monitor.h" diff --git a/src/v/raft/follower_stats.cc b/src/v/raft/follower_stats.cc index 4983491da1340..c8fc7d7735b13 100644 --- a/src/v/raft/follower_stats.cc +++ b/src/v/raft/follower_stats.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/follower_stats.h" namespace raft { diff --git a/src/v/raft/follower_stats.h b/src/v/raft/follower_stats.h index fb0571846276b..4a396f5895b36 100644 --- a/src/v/raft/follower_stats.h +++ b/src/v/raft/follower_stats.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/types.h" diff --git a/src/v/raft/group_manager.cc b/src/v/raft/group_manager.cc index 1a90887a4bcad..06684a6920170 100644 --- a/src/v/raft/group_manager.cc +++ b/src/v/raft/group_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/group_manager.h" #include "config/configuration.h" diff --git a/src/v/raft/group_manager.h b/src/v/raft/group_manager.h index ce22df4f1c1bd..84e25ae67d016 100644 --- a/src/v/raft/group_manager.h +++ b/src/v/raft/group_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/types.h" #include "raft/consensus.h" diff --git a/src/v/raft/heartbeat_manager.cc b/src/v/raft/heartbeat_manager.cc index 26ca607dad3dd..5c2e1a2b99d2f 100644 --- a/src/v/raft/heartbeat_manager.cc +++ b/src/v/raft/heartbeat_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/heartbeat_manager.h" #include "config/configuration.h" diff --git a/src/v/raft/heartbeat_manager.h b/src/v/raft/heartbeat_manager.h index 2386a289549a3..390f9f9e518c4 100644 --- a/src/v/raft/heartbeat_manager.h +++ b/src/v/raft/heartbeat_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/configuration.h" diff --git a/src/v/raft/kvelldb/errc.h b/src/v/raft/kvelldb/errc.h index 9e703baa70b67..13534a2d00f8c 100644 --- a/src/v/raft/kvelldb/errc.h +++ b/src/v/raft/kvelldb/errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/raft/kvelldb/httpkvrsm.cc b/src/v/raft/kvelldb/httpkvrsm.cc index 0e762d12d3bcd..e2e6895ef6d23 100644 --- a/src/v/raft/kvelldb/httpkvrsm.cc +++ b/src/v/raft/kvelldb/httpkvrsm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/kvelldb/httpkvrsm.h" #include "json/json.h" diff --git a/src/v/raft/kvelldb/httpkvrsm.h b/src/v/raft/kvelldb/httpkvrsm.h index 803e1c6a0d758..b2406126fa19b 100644 --- a/src/v/raft/kvelldb/httpkvrsm.h +++ b/src/v/raft/kvelldb/httpkvrsm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/kvelldb/kvrsm.h" diff --git a/src/v/raft/kvelldb/kvrsm.cc b/src/v/raft/kvelldb/kvrsm.cc index a0ad389e73fe1..df073c28964e1 100644 --- a/src/v/raft/kvelldb/kvrsm.cc +++ b/src/v/raft/kvelldb/kvrsm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/kvelldb/kvrsm.h" #include "raft/errc.h" diff --git a/src/v/raft/kvelldb/kvrsm.h b/src/v/raft/kvelldb/kvrsm.h index c81b23b3e30f0..aedd08ca878b9 100644 --- a/src/v/raft/kvelldb/kvrsm.h +++ b/src/v/raft/kvelldb/kvrsm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/raft/kvelldb/kvserver.cc b/src/v/raft/kvelldb/kvserver.cc index 6eb1a308eb1a6..965b91ed858a2 100644 --- a/src/v/raft/kvelldb/kvserver.cc +++ b/src/v/raft/kvelldb/kvserver.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/metadata.h" #include "platform/stop_signal.h" #include "raft/consensus.h" diff --git a/src/v/raft/kvelldb/logger.cc b/src/v/raft/kvelldb/logger.cc index ecde436860684..8b40c39b089e0 100644 --- a/src/v/raft/kvelldb/logger.cc +++ b/src/v/raft/kvelldb/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/kvelldb/logger.h" namespace raft::kvelldb { diff --git a/src/v/raft/kvelldb/logger.h b/src/v/raft/kvelldb/logger.h index cdda6bd957bbe..1abb992ff3bf4 100644 --- a/src/v/raft/kvelldb/logger.h +++ b/src/v/raft/kvelldb/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/raft/log_eviction_stm.cc b/src/v/raft/log_eviction_stm.cc index a4da1bb2c3b7b..7cf142d1b2573 100644 --- a/src/v/raft/log_eviction_stm.cc +++ b/src/v/raft/log_eviction_stm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/log_eviction_stm.h" #include "raft/consensus.h" diff --git a/src/v/raft/log_eviction_stm.h b/src/v/raft/log_eviction_stm.h index 77b1684f99e2f..9bb1493b7acef 100644 --- a/src/v/raft/log_eviction_stm.h +++ b/src/v/raft/log_eviction_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" #include "storage/types.h" diff --git a/src/v/raft/logger.cc b/src/v/raft/logger.cc index 8e53273e179ef..8529e9b88cbfe 100644 --- a/src/v/raft/logger.cc +++ b/src/v/raft/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/logger.h" namespace raft { diff --git a/src/v/raft/logger.h b/src/v/raft/logger.h index 6fe86366a4a5b..901603a159857 100644 --- a/src/v/raft/logger.h +++ b/src/v/raft/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/raft/mux_state_machine.h b/src/v/raft/mux_state_machine.h index 9469ee914b498..a852b7b0b4962 100644 --- a/src/v/raft/mux_state_machine.h +++ b/src/v/raft/mux_state_machine.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/raft/offset_monitor.cc b/src/v/raft/offset_monitor.cc index 5609d24663837..fee1161f51c72 100644 --- a/src/v/raft/offset_monitor.cc +++ b/src/v/raft/offset_monitor.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/offset_monitor.h" #include "vassert.h" diff --git a/src/v/raft/offset_monitor.h b/src/v/raft/offset_monitor.h index ab790959f4f80..706e67fe480b6 100644 --- a/src/v/raft/offset_monitor.h +++ b/src/v/raft/offset_monitor.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/timeout_clock.h" diff --git a/src/v/raft/prevote_stm.cc b/src/v/raft/prevote_stm.cc index 9319aaf0225bd..8ab9e454337e3 100644 --- a/src/v/raft/prevote_stm.cc +++ b/src/v/raft/prevote_stm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/prevote_stm.h" #include "model/metadata.h" diff --git a/src/v/raft/prevote_stm.h b/src/v/raft/prevote_stm.h index 35b12ab46c1eb..8c4f2d6d63e11 100644 --- a/src/v/raft/prevote_stm.h +++ b/src/v/raft/prevote_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" diff --git a/src/v/raft/probe.cc b/src/v/raft/probe.cc index c845f03b9fb26..e5b4a9848e743 100644 --- a/src/v/raft/probe.cc +++ b/src/v/raft/probe.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/probe.h" #include "config/configuration.h" diff --git a/src/v/raft/probe.h b/src/v/raft/probe.h index 3a0e66270345c..a29fe79e59ac3 100644 --- a/src/v/raft/probe.h +++ b/src/v/raft/probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/types.h" diff --git a/src/v/raft/recovery_stm.cc b/src/v/raft/recovery_stm.cc index 232ba6f5550e7..8b2c4ffd105ca 100644 --- a/src/v/raft/recovery_stm.cc +++ b/src/v/raft/recovery_stm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/recovery_stm.h" #include "model/fundamental.h" diff --git a/src/v/raft/recovery_stm.h b/src/v/raft/recovery_stm.h index 0679103da6eb2..f4a4879811628 100644 --- a/src/v/raft/recovery_stm.h +++ b/src/v/raft/recovery_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" diff --git a/src/v/raft/replicate_batcher.cc b/src/v/raft/replicate_batcher.cc index 65a6c3fdbad4e..22a0295cae741 100644 --- a/src/v/raft/replicate_batcher.cc +++ b/src/v/raft/replicate_batcher.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/replicate_batcher.h" #include "model/fundamental.h" diff --git a/src/v/raft/replicate_batcher.h b/src/v/raft/replicate_batcher.h index 69682469ebfdf..1abc2889746a7 100644 --- a/src/v/raft/replicate_batcher.h +++ b/src/v/raft/replicate_batcher.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record_batch_reader.h" diff --git a/src/v/raft/replicate_entries_stm.cc b/src/v/raft/replicate_entries_stm.cc index a95e1cb590c4d..343d2d593f239 100644 --- a/src/v/raft/replicate_entries_stm.cc +++ b/src/v/raft/replicate_entries_stm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/replicate_entries_stm.h" #include "likely.h" diff --git a/src/v/raft/replicate_entries_stm.h b/src/v/raft/replicate_entries_stm.h index 80fa7234d03e2..93a92986e1af6 100644 --- a/src/v/raft/replicate_entries_stm.h +++ b/src/v/raft/replicate_entries_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" diff --git a/src/v/raft/rpc_client_protocol.cc b/src/v/raft/rpc_client_protocol.cc index 158449dae05ca..f9f9df2e7d03f 100644 --- a/src/v/raft/rpc_client_protocol.cc +++ b/src/v/raft/rpc_client_protocol.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/rpc_client_protocol.h" #include "outcome_future_utils.h" diff --git a/src/v/raft/rpc_client_protocol.h b/src/v/raft/rpc_client_protocol.h index a1ebb24e546f6..b688b42e17a63 100644 --- a/src/v/raft/rpc_client_protocol.h +++ b/src/v/raft/rpc_client_protocol.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" diff --git a/src/v/raft/service.h b/src/v/raft/service.h index 4d0a8a7ee2f7a..5464d709333f6 100644 --- a/src/v/raft/service.h +++ b/src/v/raft/service.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/consensus.h" diff --git a/src/v/raft/state_machine.cc b/src/v/raft/state_machine.cc index 56bdfa2649fbf..134ada4b709c6 100644 --- a/src/v/raft/state_machine.cc +++ b/src/v/raft/state_machine.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/state_machine.h" #include "model/fundamental.h" diff --git a/src/v/raft/state_machine.h b/src/v/raft/state_machine.h index cade15a9ce7fb..fcec4f4e87089 100644 --- a/src/v/raft/state_machine.h +++ b/src/v/raft/state_machine.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/metadata.h" diff --git a/src/v/raft/tests/append_entries_test.cc b/src/v/raft/tests/append_entries_test.cc index 5a0c383ec4611..9feda72918b0d 100644 --- a/src/v/raft/tests/append_entries_test.cc +++ b/src/v/raft/tests/append_entries_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "finjector/hbadger.h" #include "model/fundamental.h" #include "model/metadata.h" diff --git a/src/v/raft/tests/bootstrap_configuration_test.cc b/src/v/raft/tests/bootstrap_configuration_test.cc index e988dafc75ae0..38091a86015d9 100644 --- a/src/v/raft/tests/bootstrap_configuration_test.cc +++ b/src/v/raft/tests/bootstrap_configuration_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/adl_serde.h" #include "model/fundamental.h" #include "model/metadata.h" diff --git a/src/v/raft/tests/configuration_manager_test.cc b/src/v/raft/tests/configuration_manager_test.cc index 703ba8df14862..9cc6ef638026e 100644 --- a/src/v/raft/tests/configuration_manager_test.cc +++ b/src/v/raft/tests/configuration_manager_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/metadata.h" #include "raft/configuration.h" diff --git a/src/v/raft/tests/configuration_serialization_test.cc b/src/v/raft/tests/configuration_serialization_test.cc index cc0ae83457b76..c2f16185e3e06 100644 --- a/src/v/raft/tests/configuration_serialization_test.cc +++ b/src/v/raft/tests/configuration_serialization_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/configuration.h" #include "raft/consensus_utils.h" #include "random/generators.h" diff --git a/src/v/raft/tests/consensus_utils_test.cc b/src/v/raft/tests/consensus_utils_test.cc index 288bf58125451..a18c6ce7577d3 100644 --- a/src/v/raft/tests/consensus_utils_test.cc +++ b/src/v/raft/tests/consensus_utils_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE raft #include "raft/consensus_utils.h" #include "storage/tests/utils/disk_log_builder.h" diff --git a/src/v/raft/tests/foreign_entry_test.cc b/src/v/raft/tests/foreign_entry_test.cc index ce78cb43af0f5..2dbfc85a1f829 100644 --- a/src/v/raft/tests/foreign_entry_test.cc +++ b/src/v/raft/tests/foreign_entry_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/adl_serde.h" #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/raft/tests/group_configuration_tests.cc b/src/v/raft/tests/group_configuration_tests.cc index 45c4b1b69cbb4..a18f7426ac6f7 100644 --- a/src/v/raft/tests/group_configuration_tests.cc +++ b/src/v/raft/tests/group_configuration_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/configuration.h" #include "utils/unresolved_address.h" #define BOOST_TEST_MODULE raft diff --git a/src/v/raft/tests/jitter_tests.cc b/src/v/raft/tests/jitter_tests.cc index d14c1d57feeda..500ea713195f2 100644 --- a/src/v/raft/tests/jitter_tests.cc +++ b/src/v/raft/tests/jitter_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/timeout_jitter.h" #include diff --git a/src/v/raft/tests/leadership_test.cc b/src/v/raft/tests/leadership_test.cc index aad92e5c71644..d1532460748ea 100644 --- a/src/v/raft/tests/leadership_test.cc +++ b/src/v/raft/tests/leadership_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "finjector/hbadger.h" #include "model/metadata.h" #include "model/timeout_clock.h" diff --git a/src/v/raft/tests/membership_test.cc b/src/v/raft/tests/membership_test.cc index 5b4d8b9f4184d..2da3ed4a8f3a1 100644 --- a/src/v/raft/tests/membership_test.cc +++ b/src/v/raft/tests/membership_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/metadata.h" #include "raft/errc.h" #include "raft/tests/raft_group_fixture.h" diff --git a/src/v/raft/tests/mux_state_machine_fixture.h b/src/v/raft/tests/mux_state_machine_fixture.h index 569779bd2b889..15f42428f3de5 100644 --- a/src/v/raft/tests/mux_state_machine_fixture.h +++ b/src/v/raft/tests/mux_state_machine_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #include "model/fundamental.h" diff --git a/src/v/raft/tests/mux_state_machine_test.cc b/src/v/raft/tests/mux_state_machine_test.cc index 0562352c6776f..eaa6e9a7bf709 100644 --- a/src/v/raft/tests/mux_state_machine_test.cc +++ b/src/v/raft/tests/mux_state_machine_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/record.h" #include "model/timeout_clock.h" diff --git a/src/v/raft/tests/offset_monitor_test.cc b/src/v/raft/tests/offset_monitor_test.cc index cc3f77553ec39..89905945a4c81 100644 --- a/src/v/raft/tests/offset_monitor_test.cc +++ b/src/v/raft/tests/offset_monitor_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/offset_monitor.h" #include "seastarx.h" diff --git a/src/v/raft/tests/raft_group_fixture.h b/src/v/raft/tests/raft_group_fixture.h index 1733f2e1d60e4..a4479fdcb8d86 100644 --- a/src/v/raft/tests/raft_group_fixture.h +++ b/src/v/raft/tests/raft_group_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" #include "model/record_batch_reader.h" diff --git a/src/v/raft/tests/simple_record_fixture.h b/src/v/raft/tests/simple_record_fixture.h index 060b87b01ae8a..322b5a1dc483f 100644 --- a/src/v/raft/tests/simple_record_fixture.h +++ b/src/v/raft/tests/simple_record_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record.h" diff --git a/src/v/raft/tests/term_assigning_reader_test.cc b/src/v/raft/tests/term_assigning_reader_test.cc index 4490e8a7c6eee..bab2fd45fcc9c 100644 --- a/src/v/raft/tests/term_assigning_reader_test.cc +++ b/src/v/raft/tests/term_assigning_reader_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/record_batch_reader.h" #include "model/timeout_clock.h" diff --git a/src/v/raft/tests/type_serialization_tests.cc b/src/v/raft/tests/type_serialization_tests.cc index 79041cd737301..c3c23f4032e17 100644 --- a/src/v/raft/tests/type_serialization_tests.cc +++ b/src/v/raft/tests/type_serialization_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "compression/stream_zstd.h" #include "model/record.h" #include "model/record_batch_reader.h" diff --git a/src/v/raft/timeout_jitter.h b/src/v/raft/timeout_jitter.h index 18e31733feaf9..645fffbcf07e5 100644 --- a/src/v/raft/timeout_jitter.h +++ b/src/v/raft/timeout_jitter.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "raft/types.h" diff --git a/src/v/raft/tron/client.cc b/src/v/raft/tron/client.cc index 994cfc261880f..6a36322036f70 100644 --- a/src/v/raft/tron/client.cc +++ b/src/v/raft/tron/client.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record_batch_reader.h" #include "raft/tron/logger.h" #include "raft/tron/service.h" diff --git a/src/v/raft/tron/logger.cc b/src/v/raft/tron/logger.cc index 9a5682159e190..b53df0b0d44bd 100644 --- a/src/v/raft/tron/logger.cc +++ b/src/v/raft/tron/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/tron/logger.h" namespace raft::tron { diff --git a/src/v/raft/tron/logger.h b/src/v/raft/tron/logger.h index b150a3d305cdd..aa2812223c6dd 100644 --- a/src/v/raft/tron/logger.h +++ b/src/v/raft/tron/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/raft/tron/server.cc b/src/v/raft/tron/server.cc index 2629f5acc2b4e..d86502c07d12a 100644 --- a/src/v/raft/tron/server.cc +++ b/src/v/raft/tron/server.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/server.h" #include "platform/stop_signal.h" diff --git a/src/v/raft/tron/service.h b/src/v/raft/tron/service.h index 217c3d5ae945e..daa8aed385c4e 100644 --- a/src/v/raft/tron/service.h +++ b/src/v/raft/tron/service.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record_batch_reader.h" diff --git a/src/v/raft/tron/types.h b/src/v/raft/tron/types.h index e6ed7f0ce3238..e3c870d8dfbaf 100644 --- a/src/v/raft/tron/types.h +++ b/src/v/raft/tron/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/raft/types.cc b/src/v/raft/types.cc index 642274fbd9e8d..ac2514c3ccf08 100644 --- a/src/v/raft/types.cc +++ b/src/v/raft/types.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/types.h" #include "model/fundamental.h" diff --git a/src/v/raft/types.h b/src/v/raft/types.h index 78b13052e3320..bbbe89dcac216 100644 --- a/src/v/raft/types.h +++ b/src/v/raft/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/adl_serde.h" diff --git a/src/v/raft/vote_stm.cc b/src/v/raft/vote_stm.cc index 82e15ba62b9e9..87e86d358efb2 100644 --- a/src/v/raft/vote_stm.cc +++ b/src/v/raft/vote_stm.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "raft/vote_stm.h" #include "outcome_future_utils.h" diff --git a/src/v/raft/vote_stm.h b/src/v/raft/vote_stm.h index d28e839ad1e05..f7248386676e5 100644 --- a/src/v/raft/vote_stm.h +++ b/src/v/raft/vote_stm.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" diff --git a/src/v/random/fast_prng.h b/src/v/random/fast_prng.h index 17e2b60031446..f617c52535928 100644 --- a/src/v/random/fast_prng.h +++ b/src/v/random/fast_prng.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/random/generators.h b/src/v/random/generators.h index 42d888739a507..436fb64af351a 100644 --- a/src/v/random/generators.h +++ b/src/v/random/generators.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/random/random_test.cc b/src/v/random/random_test.cc index d923d4a636281..ae5fc1e8cdbea 100644 --- a/src/v/random/random_test.cc +++ b/src/v/random/random_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE random #include "random/fast_prng.h" #include "random/generators.h" diff --git a/src/v/random/simple_time_jitter.h b/src/v/random/simple_time_jitter.h index b06eff1dd79ec..4d521b60290d6 100644 --- a/src/v/random/simple_time_jitter.h +++ b/src/v/random/simple_time_jitter.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "random/fast_prng.h" diff --git a/src/v/redpanda/application.cc b/src/v/redpanda/application.cc index 2a3d0355905b0..e15760500beb2 100644 --- a/src/v/redpanda/application.cc +++ b/src/v/redpanda/application.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "redpanda/application.h" #include "cluster/metadata_dissemination_handler.h" diff --git a/src/v/redpanda/application.h b/src/v/redpanda/application.h index 8ff5c7fea0d83..4680edd547c52 100644 --- a/src/v/redpanda/application.h +++ b/src/v/redpanda/application.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/controller.h" diff --git a/src/v/redpanda/main.cc b/src/v/redpanda/main.cc index 11d068b01a180..84b541708c58e 100644 --- a/src/v/redpanda/main.cc +++ b/src/v/redpanda/main.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "redpanda/application.h" #include "syschecks/syschecks.h" diff --git a/src/v/redpanda/tests/fixture.h b/src/v/redpanda/tests/fixture.h index 6a04995a1f4f3..ddf5dbd129c22 100644 --- a/src/v/redpanda/tests/fixture.h +++ b/src/v/redpanda/tests/fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "cluster/namespace.h" #include "cluster/types.h" diff --git a/src/v/reflection/adl.h b/src/v/reflection/adl.h index 780dd5aa273e6..f47f24d8bd39b 100644 --- a/src/v/reflection/adl.h +++ b/src/v/reflection/adl.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/reflection/arity.h b/src/v/reflection/arity.h index caa4afa626ca0..69dfa8b16990c 100644 --- a/src/v/reflection/arity.h +++ b/src/v/reflection/arity.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // Credits: originally taken from cista.rocks (MIT License) diff --git a/src/v/reflection/async_adl.h b/src/v/reflection/async_adl.h index 335e6be5c1a72..72d338d0872bf 100644 --- a/src/v/reflection/async_adl.h +++ b/src/v/reflection/async_adl.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "reflection/adl.h" #include "ssx/future-util.h" diff --git a/src/v/reflection/for_each_field.h b/src/v/reflection/for_each_field.h index c59e1266f8e2b..2b76de7303a9a 100644 --- a/src/v/reflection/for_each_field.h +++ b/src/v/reflection/for_each_field.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // Credits: originally taken from cista.rocks (MIT License) diff --git a/src/v/reflection/test/arity_test.cc b/src/v/reflection/test/arity_test.cc index 8dad22cfad718..3b7b218827ca3 100644 --- a/src/v/reflection/test/arity_test.cc +++ b/src/v/reflection/test/arity_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE reflection #include "reflection/arity.h" diff --git a/src/v/reflection/test/async_adl_test.cc b/src/v/reflection/test/async_adl_test.cc index fdca97f3f9a31..3e2bc6a2557e2 100644 --- a/src/v/reflection/test/async_adl_test.cc +++ b/src/v/reflection/test/async_adl_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "bytes/iobuf_parser.h" #include "model/adl_serde.h" diff --git a/src/v/reflection/to_tuple.h b/src/v/reflection/to_tuple.h index 02a3a3920461e..840060d73c3e0 100644 --- a/src/v/reflection/to_tuple.h +++ b/src/v/reflection/to_tuple.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // derived from cista.rocks diff --git a/src/v/resource_mgmt/cpu_scheduling.h b/src/v/resource_mgmt/cpu_scheduling.h index 4d87e05d2c4aa..b8435983f6a7f 100644 --- a/src/v/resource_mgmt/cpu_scheduling.h +++ b/src/v/resource_mgmt/cpu_scheduling.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/resource_mgmt/io_priority.h b/src/v/resource_mgmt/io_priority.h index 1906d90976626..af337f445b5be 100644 --- a/src/v/resource_mgmt/io_priority.h +++ b/src/v/resource_mgmt/io_priority.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/resource_mgmt/memory_groups.h b/src/v/resource_mgmt/memory_groups.h index e8b9edb33a176..76fdcb119590f 100644 --- a/src/v/resource_mgmt/memory_groups.h +++ b/src/v/resource_mgmt/memory_groups.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/resource_mgmt/rate.h b/src/v/resource_mgmt/rate.h index 382141dfc1a68..a4a4a281cdac6 100644 --- a/src/v/resource_mgmt/rate.h +++ b/src/v/resource_mgmt/rate.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/resource_mgmt/smp_groups.h b/src/v/resource_mgmt/smp_groups.h index 69b77b5cabc8c..c8b8892959b28 100644 --- a/src/v/resource_mgmt/smp_groups.h +++ b/src/v/resource_mgmt/smp_groups.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/backoff_policy.h b/src/v/rpc/backoff_policy.h index abd38e41922e6..73b62550707b4 100644 --- a/src/v/rpc/backoff_policy.h +++ b/src/v/rpc/backoff_policy.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/batched_output_stream.cc b/src/v/rpc/batched_output_stream.cc index 67b20ee374f59..6809b8d6a3d10 100644 --- a/src/v/rpc/batched_output_stream.cc +++ b/src/v/rpc/batched_output_stream.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/batched_output_stream.h" #include "likely.h" diff --git a/src/v/rpc/batched_output_stream.h b/src/v/rpc/batched_output_stream.h index a8fe3f87ead47..038ee02796e77 100644 --- a/src/v/rpc/batched_output_stream.h +++ b/src/v/rpc/batched_output_stream.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/client_probe.h b/src/v/rpc/client_probe.h index 57679aa7247a6..c2935f2008750 100644 --- a/src/v/rpc/client_probe.h +++ b/src/v/rpc/client_probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "rpc/logger.h" diff --git a/src/v/rpc/connection.cc b/src/v/rpc/connection.cc index d1bbbd6532953..ced0abed8a204 100644 --- a/src/v/rpc/connection.cc +++ b/src/v/rpc/connection.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/connection.h" #include "rpc/logger.h" diff --git a/src/v/rpc/connection.h b/src/v/rpc/connection.h index 233232dadf734..f1c1d2b827499 100644 --- a/src/v/rpc/connection.h +++ b/src/v/rpc/connection.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "rpc/batched_output_stream.h" diff --git a/src/v/rpc/connection_cache.cc b/src/v/rpc/connection_cache.cc index 4bdf548aeb925..7235b9c96dc1d 100644 --- a/src/v/rpc/connection_cache.cc +++ b/src/v/rpc/connection_cache.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/connection_cache.h" #include "rpc/backoff_policy.h" diff --git a/src/v/rpc/connection_cache.h b/src/v/rpc/connection_cache.h index f347153f8da40..5097a8e9220dc 100644 --- a/src/v/rpc/connection_cache.h +++ b/src/v/rpc/connection_cache.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "hashing/jump_consistent_hash.h" #include "model/metadata.h" diff --git a/src/v/rpc/demo/client.cc b/src/v/rpc/demo/client.cc index 69171196a1cbc..0021ed281eb0d 100644 --- a/src/v/rpc/demo/client.cc +++ b/src/v/rpc/demo/client.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/demo/demo_utils.h" #include "rpc/demo/simple_service.h" #include "rpc/types.h" diff --git a/src/v/rpc/demo/demo_utils.h b/src/v/rpc/demo/demo_utils.h index fcc6b6e7cd778..c3ce82eccfe71 100644 --- a/src/v/rpc/demo/demo_utils.h +++ b/src/v/rpc/demo/demo_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #include "reflection/arity.h" #include "reflection/for_each_field.h" #include "rpc/demo/types.h" diff --git a/src/v/rpc/demo/server.cc b/src/v/rpc/demo/server.cc index 6c745f9eeddd2..3334b8d102be4 100644 --- a/src/v/rpc/demo/server.cc +++ b/src/v/rpc/demo/server.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/server.h" #include "rpc/demo/demo_utils.h" diff --git a/src/v/rpc/demo/type_tests.cc b/src/v/rpc/demo/type_tests.cc index 79b31592f25d6..b52f0df19f298 100644 --- a/src/v/rpc/demo/type_tests.cc +++ b/src/v/rpc/demo/type_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "reflection/adl.h" #include "rpc/demo/demo_utils.h" #include "rpc/demo/types.h" diff --git a/src/v/rpc/demo/types.h b/src/v/rpc/demo/types.h index 79f80c4e5f003..08844882cad97 100644 --- a/src/v/rpc/demo/types.h +++ b/src/v/rpc/demo/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/rpc/errc.h b/src/v/rpc/errc.h index 7adf1f6982493..42cc4824f5d8e 100644 --- a/src/v/rpc/errc.h +++ b/src/v/rpc/errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/rpc/exceptions.h b/src/v/rpc/exceptions.h index f3bc9a1a92a62..cd11375104948 100644 --- a/src/v/rpc/exceptions.h +++ b/src/v/rpc/exceptions.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/logger.cc b/src/v/rpc/logger.cc index dac2d8711c2a6..624f6501bb1c6 100644 --- a/src/v/rpc/logger.cc +++ b/src/v/rpc/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/logger.h" namespace rpc { diff --git a/src/v/rpc/logger.h b/src/v/rpc/logger.h index f7c292c75daa1..57bb7a397cea5 100644 --- a/src/v/rpc/logger.h +++ b/src/v/rpc/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/netbuf.cc b/src/v/rpc/netbuf.cc index bcf431111efd6..d47a119d62651 100644 --- a/src/v/rpc/netbuf.cc +++ b/src/v/rpc/netbuf.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/netbuf.h" #include "bytes/iobuf.h" diff --git a/src/v/rpc/netbuf.h b/src/v/rpc/netbuf.h index cbb82d09e004d..a5b46eb6f2acb 100644 --- a/src/v/rpc/netbuf.h +++ b/src/v/rpc/netbuf.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/rpc/parse_utils.h b/src/v/rpc/parse_utils.h index 55cbc75922db2..472767294a21d 100644 --- a/src/v/rpc/parse_utils.h +++ b/src/v/rpc/parse_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "compression/stream_zstd.h" diff --git a/src/v/rpc/probes.cc b/src/v/rpc/probes.cc index 466993257145d..32edf55e75e2a 100644 --- a/src/v/rpc/probes.cc +++ b/src/v/rpc/probes.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "prometheus/prometheus_sanitize.h" #include "rpc/client_probe.h" #include "rpc/server_probe.h" diff --git a/src/v/rpc/reconnect_transport.cc b/src/v/rpc/reconnect_transport.cc index 561188879b703..81c1105a279ec 100644 --- a/src/v/rpc/reconnect_transport.cc +++ b/src/v/rpc/reconnect_transport.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/reconnect_transport.h" #include "raft/logger.h" diff --git a/src/v/rpc/reconnect_transport.h b/src/v/rpc/reconnect_transport.h index 593ec76faf80f..c43af25fae430 100644 --- a/src/v/rpc/reconnect_transport.h +++ b/src/v/rpc/reconnect_transport.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" diff --git a/src/v/rpc/response_handler.h b/src/v/rpc/response_handler.h index 6ce244c0ba57e..0d466d44b63ec 100644 --- a/src/v/rpc/response_handler.h +++ b/src/v/rpc/response_handler.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" #include "rpc/errc.h" diff --git a/src/v/rpc/server.cc b/src/v/rpc/server.cc index 1fc09295bf81b..366bb5282764d 100644 --- a/src/v/rpc/server.cc +++ b/src/v/rpc/server.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/server.h" #include "likely.h" diff --git a/src/v/rpc/server.h b/src/v/rpc/server.h index e639f7df3c5e6..fb3ea82cc2ce9 100644 --- a/src/v/rpc/server.h +++ b/src/v/rpc/server.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "rpc/connection.h" diff --git a/src/v/rpc/server_probe.h b/src/v/rpc/server_probe.h index 19635a633b133..5699695638647 100644 --- a/src/v/rpc/server_probe.h +++ b/src/v/rpc/server_probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/service.h b/src/v/rpc/service.h index 4dc55f593f153..e8f288cd1957a 100644 --- a/src/v/rpc/service.h +++ b/src/v/rpc/service.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "reflection/async_adl.h" diff --git a/src/v/rpc/simple_protocol.cc b/src/v/rpc/simple_protocol.cc index b92cf5b84696e..8330cbdc11672 100644 --- a/src/v/rpc/simple_protocol.cc +++ b/src/v/rpc/simple_protocol.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/simple_protocol.h" #include "rpc/logger.h" diff --git a/src/v/rpc/simple_protocol.h b/src/v/rpc/simple_protocol.h index d21540f9646fc..68379bc31950d 100644 --- a/src/v/rpc/simple_protocol.h +++ b/src/v/rpc/simple_protocol.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "rpc/netbuf.h" #include "rpc/server.h" diff --git a/src/v/rpc/test/exponential_backoff.cc b/src/v/rpc/test/exponential_backoff.cc index 7265af8fbbe85..e275eece8be68 100644 --- a/src/v/rpc/test/exponential_backoff.cc +++ b/src/v/rpc/test/exponential_backoff.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include #include diff --git a/src/v/rpc/test/netbuf_tests.cc b/src/v/rpc/test/netbuf_tests.cc index 9718007319b74..2cd2a2d9fb266 100644 --- a/src/v/rpc/test/netbuf_tests.cc +++ b/src/v/rpc/test/netbuf_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/netbuf.h" #include "rpc/parse_utils.h" diff --git a/src/v/rpc/test/response_handler_tests.cc b/src/v/rpc/test/response_handler_tests.cc index 9ed6bb9fd653d..2e06d190de1a5 100644 --- a/src/v/rpc/test/response_handler_tests.cc +++ b/src/v/rpc/test/response_handler_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/response_handler.h" #include "rpc/types.h" #include "test_utils/fixture.h" diff --git a/src/v/rpc/test/roundtrip_tests.cc b/src/v/rpc/test/roundtrip_tests.cc index 75880bab1fe4e..20962424078db 100644 --- a/src/v/rpc/test/roundtrip_tests.cc +++ b/src/v/rpc/test/roundtrip_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "reflection/adl.h" #include diff --git a/src/v/rpc/test/rpc_bench.cc b/src/v/rpc/test/rpc_bench.cc index b544a54330fb6..485cc0e5688fb 100644 --- a/src/v/rpc/test/rpc_bench.cc +++ b/src/v/rpc/test/rpc_bench.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "reflection/adl.h" #include diff --git a/src/v/rpc/test/rpc_gen_cycling_test.cc b/src/v/rpc/test/rpc_gen_cycling_test.cc index f555f6922fb7c..00ebe9db5506b 100644 --- a/src/v/rpc/test/rpc_gen_cycling_test.cc +++ b/src/v/rpc/test/rpc_gen_cycling_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/timeout_clock.h" #include "random/generators.h" #include "rpc/exceptions.h" diff --git a/src/v/rpc/test/rpc_gen_types.h b/src/v/rpc/test/rpc_gen_types.h index 7cb4c33a3152d..1b60cafac2d3c 100644 --- a/src/v/rpc/test/rpc_gen_types.h +++ b/src/v/rpc/test/rpc_gen_types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/rpc/test/rpc_integration_fixture.h b/src/v/rpc/test/rpc_integration_fixture.h index 3666a801a3773..d2a4a4beb8b14 100644 --- a/src/v/rpc/test/rpc_integration_fixture.h +++ b/src/v/rpc/test/rpc_integration_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/tls_config.h" #include "rpc/server.h" diff --git a/src/v/rpc/test/serialization_test.cc b/src/v/rpc/test/serialization_test.cc index fd3048f355040..c7b9d8b944862 100644 --- a/src/v/rpc/test/serialization_test.cc +++ b/src/v/rpc/test/serialization_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "reflection/adl.h" #include "reflection/arity.h" diff --git a/src/v/rpc/test/test_types.h b/src/v/rpc/test/test_types.h index 988901ad643cf..2653a5d53e19d 100644 --- a/src/v/rpc/test/test_types.h +++ b/src/v/rpc/test/test_types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/rpc/transport.cc b/src/v/rpc/transport.cc index 7e8325d98eed8..a7a49df4ddbe5 100644 --- a/src/v/rpc/transport.cc +++ b/src/v/rpc/transport.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/transport.h" #include "likely.h" diff --git a/src/v/rpc/transport.h b/src/v/rpc/transport.h index 8e5a9829887c8..998fae435c401 100644 --- a/src/v/rpc/transport.h +++ b/src/v/rpc/transport.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "outcome.h" diff --git a/src/v/rpc/types.cc b/src/v/rpc/types.cc index 48b39bdc9623a..7bb0f3460c88a 100644 --- a/src/v/rpc/types.cc +++ b/src/v/rpc/types.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "rpc/types.h" #include "hashing/crc32c.h" diff --git a/src/v/rpc/types.h b/src/v/rpc/types.h index 9ad495e8ab2be..dfc89952b8418 100644 --- a/src/v/rpc/types.h +++ b/src/v/rpc/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/seastarx.h b/src/v/seastarx.h index 7c8b05d298e80..cb6365d85cfa8 100644 --- a/src/v/seastarx.h +++ b/src/v/seastarx.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once namespace seastar {} // namespace seastar diff --git a/src/v/ssx/future-util.h b/src/v/ssx/future-util.h index e3b2ab79427ed..a150896aebf64 100644 --- a/src/v/ssx/future-util.h +++ b/src/v/ssx/future-util.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "utils/concepts-enabled.h" diff --git a/src/v/ssx/tests/async_transforms.cc b/src/v/ssx/tests/async_transforms.cc index 12aebcbf3ea8b..9a6d32aa3a9a6 100644 --- a/src/v/ssx/tests/async_transforms.cc +++ b/src/v/ssx/tests/async_transforms.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "ssx/future-util.h" #include diff --git a/src/v/static_deleter_fn.h b/src/v/static_deleter_fn.h index 89c3b68e84d8d..f99944eeaf8f7 100644 --- a/src/v/static_deleter_fn.h +++ b/src/v/static_deleter_fn.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/storage/api.h b/src/v/storage/api.h index cef074bafb025..8fa10e4e5818b 100644 --- a/src/v/storage/api.h +++ b/src/v/storage/api.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/storage/batch_cache.cc b/src/v/storage/batch_cache.cc index ababe877c2e2f..8d48177f31f74 100644 --- a/src/v/storage/batch_cache.cc +++ b/src/v/storage/batch_cache.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "batch_cache.h" #include "vassert.h" diff --git a/src/v/storage/batch_cache.h b/src/v/storage/batch_cache.h index c2547e77e9f08..30ea930a8f6be 100644 --- a/src/v/storage/batch_cache.h +++ b/src/v/storage/batch_cache.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "config/configuration.h" #include "model/record.h" diff --git a/src/v/storage/compacted_index.h b/src/v/storage/compacted_index.h index a6cb8d32fa232..64c5c9fcda1d1 100644 --- a/src/v/storage/compacted_index.h +++ b/src/v/storage/compacted_index.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" #include "model/fundamental.h" diff --git a/src/v/storage/compacted_index_chunk_reader.cc b/src/v/storage/compacted_index_chunk_reader.cc index 451cc6acbbcf4..371fcafa72723 100644 --- a/src/v/storage/compacted_index_chunk_reader.cc +++ b/src/v/storage/compacted_index_chunk_reader.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/compacted_index_chunk_reader.h" #include "bytes/iobuf.h" diff --git a/src/v/storage/compacted_index_chunk_reader.h b/src/v/storage/compacted_index_chunk_reader.h index a6215c8447c14..abb32fe28b9d2 100644 --- a/src/v/storage/compacted_index_chunk_reader.h +++ b/src/v/storage/compacted_index_chunk_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/compacted_index_reader.h" diff --git a/src/v/storage/compacted_index_reader.h b/src/v/storage/compacted_index_reader.h index 0ea0aa8e22471..ab60afbcc6641 100644 --- a/src/v/storage/compacted_index_reader.h +++ b/src/v/storage/compacted_index_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/timeout_clock.h" diff --git a/src/v/storage/compacted_index_writer.h b/src/v/storage/compacted_index_writer.h index afb3e3592fd41..e557f480c4469 100644 --- a/src/v/storage/compacted_index_writer.h +++ b/src/v/storage/compacted_index_writer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" #include "model/fundamental.h" diff --git a/src/v/storage/compacted_offset_list.h b/src/v/storage/compacted_offset_list.h index 32352779825b1..a7f3cb88f0660 100644 --- a/src/v/storage/compacted_offset_list.h +++ b/src/v/storage/compacted_offset_list.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/compaction_reducers.cc b/src/v/storage/compaction_reducers.cc index ddb12aa1767e4..809c10c4c730f 100644 --- a/src/v/storage/compaction_reducers.cc +++ b/src/v/storage/compaction_reducers.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/compaction_reducers.h" #include "compression/compression.h" diff --git a/src/v/storage/compaction_reducers.h b/src/v/storage/compaction_reducers.h index 22f7ba1ca31db..7f1d0abd384c3 100644 --- a/src/v/storage/compaction_reducers.h +++ b/src/v/storage/compaction_reducers.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record_batch_reader.h" diff --git a/src/v/storage/directories.h b/src/v/storage/directories.h index 44e9e72a6c2b6..497a310335fa7 100644 --- a/src/v/storage/directories.h +++ b/src/v/storage/directories.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/storage/disk_log_appender.cc b/src/v/storage/disk_log_appender.cc index 69dc2fb61c251..0926b994de1d7 100644 --- a/src/v/storage/disk_log_appender.cc +++ b/src/v/storage/disk_log_appender.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/disk_log_appender.h" #include "likely.h" diff --git a/src/v/storage/disk_log_appender.h b/src/v/storage/disk_log_appender.h index 4ba097930dbf7..f0c369bfde8a3 100644 --- a/src/v/storage/disk_log_appender.h +++ b/src/v/storage/disk_log_appender.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/log_appender.h" diff --git a/src/v/storage/disk_log_impl.cc b/src/v/storage/disk_log_impl.cc index f1d047aac5125..eb442af4c3dbb 100644 --- a/src/v/storage/disk_log_impl.cc +++ b/src/v/storage/disk_log_impl.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/disk_log_impl.h" #include "model/adl_serde.h" diff --git a/src/v/storage/disk_log_impl.h b/src/v/storage/disk_log_impl.h index 78a41dedbcd7a..fe08fce008e64 100644 --- a/src/v/storage/disk_log_impl.h +++ b/src/v/storage/disk_log_impl.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/exceptions.h b/src/v/storage/exceptions.h index d9cf02e53b48b..0a4ca30e84dc2 100644 --- a/src/v/storage/exceptions.h +++ b/src/v/storage/exceptions.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/storage/failure_probes.h b/src/v/storage/failure_probes.h index 7b730e0132375..0063988b46509 100644 --- a/src/v/storage/failure_probes.h +++ b/src/v/storage/failure_probes.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "finjector/hbadger.h" #include "random/fast_prng.h" diff --git a/src/v/storage/fs_utils.h b/src/v/storage/fs_utils.h index ba7572e981b46..2e42f88f7ccd9 100644 --- a/src/v/storage/fs_utils.h +++ b/src/v/storage/fs_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "seastarx.h" diff --git a/src/v/storage/index_state.cc b/src/v/storage/index_state.cc index 2d27b2a8baa70..423c4ae6a8aba 100644 --- a/src/v/storage/index_state.cc +++ b/src/v/storage/index_state.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/index_state.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/storage/index_state.h b/src/v/storage/index_state.h index 42fd3d63e6d8f..27314c91ef87e 100644 --- a/src/v/storage/index_state.h +++ b/src/v/storage/index_state.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/storage/kvstore.cc b/src/v/storage/kvstore.cc index 256671272662b..74f3e54e9771e 100644 --- a/src/v/storage/kvstore.cc +++ b/src/v/storage/kvstore.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/kvstore.h" #include "bytes/iobuf.h" diff --git a/src/v/storage/kvstore.h b/src/v/storage/kvstore.h index 8715d02f5d554..b8ba43bdeb8ef 100644 --- a/src/v/storage/kvstore.h +++ b/src/v/storage/kvstore.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "seastarx.h" diff --git a/src/v/storage/lock_manager.cc b/src/v/storage/lock_manager.cc index e76e355249683..a256c86a4be06 100644 --- a/src/v/storage/lock_manager.cc +++ b/src/v/storage/lock_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/lock_manager.h" #include diff --git a/src/v/storage/lock_manager.h b/src/v/storage/lock_manager.h index 6f725467e5e0c..44a84ee9a6d3e 100644 --- a/src/v/storage/lock_manager.h +++ b/src/v/storage/lock_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // important to keep dependencies small because this type is used diff --git a/src/v/storage/log.h b/src/v/storage/log.h index 43a2302ea8753..14f82d9dc38ba 100644 --- a/src/v/storage/log.h +++ b/src/v/storage/log.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/record_batch_reader.h" diff --git a/src/v/storage/log_appender.h b/src/v/storage/log_appender.h index 4b720fa546a1a..5e605f7bd8b9c 100644 --- a/src/v/storage/log_appender.h +++ b/src/v/storage/log_appender.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/storage/log_housekeeping_meta.h b/src/v/storage/log_housekeeping_meta.h index 2212ce3fbb996..06c37b04b46d8 100644 --- a/src/v/storage/log_housekeeping_meta.h +++ b/src/v/storage/log_housekeeping_meta.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/log.h" diff --git a/src/v/storage/log_manager.cc b/src/v/storage/log_manager.cc index c718016e30402..cc176248a2f35 100644 --- a/src/v/storage/log_manager.cc +++ b/src/v/storage/log_manager.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/log_manager.h" #include "config/configuration.h" diff --git a/src/v/storage/log_manager.h b/src/v/storage/log_manager.h index f0ca1aad89206..048050ce8602f 100644 --- a/src/v/storage/log_manager.h +++ b/src/v/storage/log_manager.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/log_reader.cc b/src/v/storage/log_reader.cc index 2bc44035e97e4..5663105fdfb6e 100644 --- a/src/v/storage/log_reader.cc +++ b/src/v/storage/log_reader.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/log_reader.h" #include "bytes/iobuf.h" diff --git a/src/v/storage/log_reader.h b/src/v/storage/log_reader.h index 434f8d2e0e1cf..c04c46da6533c 100644 --- a/src/v/storage/log_reader.h +++ b/src/v/storage/log_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/storage/log_replayer.cc b/src/v/storage/log_replayer.cc index 61c8dc7310165..ba7fb85a0c4ab 100644 --- a/src/v/storage/log_replayer.cc +++ b/src/v/storage/log_replayer.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/log_replayer.h" #include "hashing/crc32c.h" diff --git a/src/v/storage/log_replayer.h b/src/v/storage/log_replayer.h index eba795062f0a9..08c3699d3bf57 100644 --- a/src/v/storage/log_replayer.h +++ b/src/v/storage/log_replayer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/logger.cc b/src/v/storage/logger.cc index 34cffea7f9393..0b958e9ce3b7a 100644 --- a/src/v/storage/logger.cc +++ b/src/v/storage/logger.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/logger.h" namespace storage { diff --git a/src/v/storage/logger.h b/src/v/storage/logger.h index e02e92e721d1e..3b65f5f72eaf1 100644 --- a/src/v/storage/logger.h +++ b/src/v/storage/logger.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/storage/mem_log_impl.cc b/src/v/storage/mem_log_impl.cc index bd776f3056571..f5abab7fdac12 100644 --- a/src/v/storage/mem_log_impl.cc +++ b/src/v/storage/mem_log_impl.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "likely.h" #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/storage/ntp_config.h b/src/v/storage/ntp_config.h index 2149a6b78dcd1..7495ad898f081 100644 --- a/src/v/storage/ntp_config.h +++ b/src/v/storage/ntp_config.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "tristate.h" diff --git a/src/v/storage/offset_assignment.h b/src/v/storage/offset_assignment.h index a0158d0dc9978..74dfd64b0f105 100644 --- a/src/v/storage/offset_assignment.h +++ b/src/v/storage/offset_assignment.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record.h" diff --git a/src/v/storage/offset_to_filepos_consumer.h b/src/v/storage/offset_to_filepos_consumer.h index 8eb8f41ea71ee..32b904c494d96 100644 --- a/src/v/storage/offset_to_filepos_consumer.h +++ b/src/v/storage/offset_to_filepos_consumer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/opfuzz/opfuzz.cc b/src/v/storage/opfuzz/opfuzz.cc index 761395890704d..8128bfb636c8c 100644 --- a/src/v/storage/opfuzz/opfuzz.cc +++ b/src/v/storage/opfuzz/opfuzz.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/opfuzz/opfuzz.h" #include "model/record.h" diff --git a/src/v/storage/opfuzz/opfuzz.h b/src/v/storage/opfuzz/opfuzz.h index 2278020f5d102..1f97066fbe57b 100644 --- a/src/v/storage/opfuzz/opfuzz.h +++ b/src/v/storage/opfuzz/opfuzz.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/opfuzz/opfuzz_test.cc b/src/v/storage/opfuzz/opfuzz_test.cc index 5770a0e2fe050..11e62f28d7679 100644 --- a/src/v/storage/opfuzz/opfuzz_test.cc +++ b/src/v/storage/opfuzz/opfuzz_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "random/generators.h" #include "storage/opfuzz/opfuzz.h" diff --git a/src/v/storage/parser.cc b/src/v/storage/parser.cc index 2528f882d9de3..0f152150ef5b8 100644 --- a/src/v/storage/parser.cc +++ b/src/v/storage/parser.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/parser.h" #include "bytes/iobuf.h" diff --git a/src/v/storage/parser.h b/src/v/storage/parser.h index a85addf368a0e..8d99073524a0d 100644 --- a/src/v/storage/parser.h +++ b/src/v/storage/parser.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/storage/parser_errc.h b/src/v/storage/parser_errc.h index d1bdcae9916c3..6529d1f579a4f 100644 --- a/src/v/storage/parser_errc.h +++ b/src/v/storage/parser_errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/storage/parser_utils.cc b/src/v/storage/parser_utils.cc index 80f78937ea7b2..0169ca12219ce 100644 --- a/src/v/storage/parser_utils.cc +++ b/src/v/storage/parser_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/parser_utils.h" #include "compression/compression.h" diff --git a/src/v/storage/parser_utils.h b/src/v/storage/parser_utils.h index 3cf06fe375bc5..0ddbba635c5dc 100644 --- a/src/v/storage/parser_utils.h +++ b/src/v/storage/parser_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf_parser.h" diff --git a/src/v/storage/probe.cc b/src/v/storage/probe.cc index 1588d63609616..41f6b6c1311fe 100644 --- a/src/v/storage/probe.cc +++ b/src/v/storage/probe.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/probe.h" #include "config/configuration.h" diff --git a/src/v/storage/probe.h b/src/v/storage/probe.h index 232ae1ebc6297..dbd510301e752 100644 --- a/src/v/storage/probe.h +++ b/src/v/storage/probe.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "storage/logger.h" diff --git a/src/v/storage/record_batch_builder.cc b/src/v/storage/record_batch_builder.cc index debd651763999..9cf70d8b08b5b 100644 --- a/src/v/storage/record_batch_builder.cc +++ b/src/v/storage/record_batch_builder.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/record_batch_builder.h" #include "model/record.h" diff --git a/src/v/storage/record_batch_builder.h b/src/v/storage/record_batch_builder.h index 8c53080322941..ba7cd91f2859d 100644 --- a/src/v/storage/record_batch_builder.h +++ b/src/v/storage/record_batch_builder.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "model/record.h" diff --git a/src/v/storage/segment.cc b/src/v/storage/segment.cc index 143745e566e04..2f12915be1b71 100644 --- a/src/v/storage/segment.cc +++ b/src/v/storage/segment.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment.h" #include "compression/compression.h" diff --git a/src/v/storage/segment.h b/src/v/storage/segment.h index d5af7b654e00d..c47243546dfde 100644 --- a/src/v/storage/segment.h +++ b/src/v/storage/segment.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/batch_cache.h" diff --git a/src/v/storage/segment_appender.cc b/src/v/storage/segment_appender.cc index 7cda7c4dac973..d2032cd19ce6b 100644 --- a/src/v/storage/segment_appender.cc +++ b/src/v/storage/segment_appender.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_appender.h" #include "likely.h" diff --git a/src/v/storage/segment_appender.h b/src/v/storage/segment_appender.h index 674dd6c1b2803..4e4ea461808b4 100644 --- a/src/v/storage/segment_appender.h +++ b/src/v/storage/segment_appender.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/storage/segment_appender_chunk.h b/src/v/storage/segment_appender_chunk.h index 6d02d1aed65df..82c3899b4ef9a 100644 --- a/src/v/storage/segment_appender_chunk.h +++ b/src/v/storage/segment_appender_chunk.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" #include "units.h" diff --git a/src/v/storage/segment_appender_utils.cc b/src/v/storage/segment_appender_utils.cc index 5bbd515b5e676..05a8d55c79691 100644 --- a/src/v/storage/segment_appender_utils.cc +++ b/src/v/storage/segment_appender_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_appender_utils.h" #include "model/record.h" diff --git a/src/v/storage/segment_appender_utils.h b/src/v/storage/segment_appender_utils.h index a2f1d5ce2a1e4..06f1c71d007ac 100644 --- a/src/v/storage/segment_appender_utils.h +++ b/src/v/storage/segment_appender_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "model/record.h" diff --git a/src/v/storage/segment_index.cc b/src/v/storage/segment_index.cc index 414f46259eaa4..4e3ef41af56e5 100644 --- a/src/v/storage/segment_index.cc +++ b/src/v/storage/segment_index.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_index.h" #include "model/timestamp.h" diff --git a/src/v/storage/segment_index.h b/src/v/storage/segment_index.h index 44a60e2e3300d..2306bbae8afa1 100644 --- a/src/v/storage/segment_index.h +++ b/src/v/storage/segment_index.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/storage/segment_reader.cc b/src/v/storage/segment_reader.cc index 1473e7625e5d6..d866ab0df2255 100644 --- a/src/v/storage/segment_reader.cc +++ b/src/v/storage/segment_reader.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_reader.h" #include "vassert.h" diff --git a/src/v/storage/segment_reader.h b/src/v/storage/segment_reader.h index a6202308b9f5f..de7a96efbe5a8 100644 --- a/src/v/storage/segment_reader.h +++ b/src/v/storage/segment_reader.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/segment_set.cc b/src/v/storage/segment_set.cc index 3bbeed1a9b0f7..ea43c5109b930 100644 --- a/src/v/storage/segment_set.cc +++ b/src/v/storage/segment_set.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_set.h" #include "storage/fs_utils.h" diff --git a/src/v/storage/segment_set.h b/src/v/storage/segment_set.h index cda45f29f2201..82dbac6a26743 100644 --- a/src/v/storage/segment_set.h +++ b/src/v/storage/segment_set.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/segment.h" diff --git a/src/v/storage/segment_utils.cc b/src/v/storage/segment_utils.cc index cc65f2d2a3dda..6130010ea2cb9 100644 --- a/src/v/storage/segment_utils.cc +++ b/src/v/storage/segment_utils.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_utils.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/storage/segment_utils.h b/src/v/storage/segment_utils.h index 3f0340a94c617..a6e5e871186ed 100644 --- a/src/v/storage/segment_utils.h +++ b/src/v/storage/segment_utils.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record_batch_reader.h" #include "storage/compacted_index.h" diff --git a/src/v/storage/shard_assignment.h b/src/v/storage/shard_assignment.h index 3f5c94a34d214..dd62212aff869 100644 --- a/src/v/storage/shard_assignment.h +++ b/src/v/storage/shard_assignment.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "hashing/jump_consistent_hash.h" diff --git a/src/v/storage/snapshot.cc b/src/v/storage/snapshot.cc index eb3af07c14e32..1dcd6dbe60a4d 100644 --- a/src/v/storage/snapshot.cc +++ b/src/v/storage/snapshot.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/snapshot.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/storage/snapshot.h b/src/v/storage/snapshot.h index 7efca28492564..2acf3d5848e0e 100644 --- a/src/v/storage/snapshot.h +++ b/src/v/storage/snapshot.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" #include "model/fundamental.h" diff --git a/src/v/storage/spill_key_index.cc b/src/v/storage/spill_key_index.cc index 9b6928d2376f6..e6fde06bee931 100644 --- a/src/v/storage/spill_key_index.cc +++ b/src/v/storage/spill_key_index.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/spill_key_index.h" #include "bytes/bytes.h" diff --git a/src/v/storage/spill_key_index.h b/src/v/storage/spill_key_index.h index fc68eb5991049..1d1149e922ea6 100644 --- a/src/v/storage/spill_key_index.h +++ b/src/v/storage/spill_key_index.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" #include "hashing/crc32c.h" diff --git a/src/v/storage/tests/appender_chunk_manipulations.cc b/src/v/storage/tests/appender_chunk_manipulations.cc index 4efd328c93709..3e9c6ed43470c 100644 --- a/src/v/storage/tests/appender_chunk_manipulations.cc +++ b/src/v/storage/tests/appender_chunk_manipulations.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "random/generators.h" #include "storage/segment_appender.h" diff --git a/src/v/storage/tests/batch_cache_reclaim_test.cc b/src/v/storage/tests/batch_cache_reclaim_test.cc index 3173f73d69406..10bf45746c63d 100644 --- a/src/v/storage/tests/batch_cache_reclaim_test.cc +++ b/src/v/storage/tests/batch_cache_reclaim_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "model/record.h" #include "storage/batch_cache.h" diff --git a/src/v/storage/tests/batch_cache_test.cc b/src/v/storage/tests/batch_cache_test.cc index ac6cab9ab482c..65111553c0853 100644 --- a/src/v/storage/tests/batch_cache_test.cc +++ b/src/v/storage/tests/batch_cache_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "cluster/simple_batch_builder.h" #include "model/record.h" #include "storage/batch_cache.h" diff --git a/src/v/storage/tests/compaction_idx_bench.cc b/src/v/storage/tests/compaction_idx_bench.cc index 0527cc9fcdcc6..a35326b903780 100644 --- a/src/v/storage/tests/compaction_idx_bench.cc +++ b/src/v/storage/tests/compaction_idx_bench.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" diff --git a/src/v/storage/tests/compaction_index_format_tests.cc b/src/v/storage/tests/compaction_index_format_tests.cc index 04c2386f5db63..1aabeef653e4e 100644 --- a/src/v/storage/tests/compaction_index_format_tests.cc +++ b/src/v/storage/tests/compaction_index_format_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/bytes.h" #include "bytes/iobuf_file.h" #include "bytes/iobuf_parser.h" diff --git a/src/v/storage/tests/disk_log_builder_fixture.h b/src/v/storage/tests/disk_log_builder_fixture.h index e229a6cc73247..2e6c4e99f24a9 100644 --- a/src/v/storage/tests/disk_log_builder_fixture.h +++ b/src/v/storage/tests/disk_log_builder_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "storage/tests/utils/disk_log_builder.h" diff --git a/src/v/storage/tests/disk_log_builder_test.cc b/src/v/storage/tests/disk_log_builder_test.cc index a87524411a8fc..978c7d274464d 100644 --- a/src/v/storage/tests/disk_log_builder_test.cc +++ b/src/v/storage/tests/disk_log_builder_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record.h" #include "seastarx.h" #include "storage/ntp_config.h" diff --git a/src/v/storage/tests/half_page_concurrent_dispatch.cc b/src/v/storage/tests/half_page_concurrent_dispatch.cc index 280b28def805f..a330772390e70 100644 --- a/src/v/storage/tests/half_page_concurrent_dispatch.cc +++ b/src/v/storage/tests/half_page_concurrent_dispatch.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/log_manager.h" #include "storage/record_batch_builder.h" #include "storage/tests/utils/disk_log_builder.h" diff --git a/src/v/storage/tests/kvstore_test.cc b/src/v/storage/tests/kvstore_test.cc index 51771aab38f73..9c2be468f392c 100644 --- a/src/v/storage/tests/kvstore_test.cc +++ b/src/v/storage/tests/kvstore_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "random/generators.h" #include "reflection/adl.h" #include "storage/kvstore.h" diff --git a/src/v/storage/tests/log_manager_test.cc b/src/v/storage/tests/log_manager_test.cc index 20a3dac0e1bd0..366142ce8689a 100644 --- a/src/v/storage/tests/log_manager_test.cc +++ b/src/v/storage/tests/log_manager_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/record_utils.h" #include "random/generators.h" diff --git a/src/v/storage/tests/log_replayer_test.cc b/src/v/storage/tests/log_replayer_test.cc index 0e470600e250b..b11d38e42d7d6 100644 --- a/src/v/storage/tests/log_replayer_test.cc +++ b/src/v/storage/tests/log_replayer_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record_utils.h" #include "random/generators.h" #include "seastarx.h" diff --git a/src/v/storage/tests/log_retention_tests.cc b/src/v/storage/tests/log_retention_tests.cc index 48dc67dc591fe..392266009c071 100644 --- a/src/v/storage/tests/log_retention_tests.cc +++ b/src/v/storage/tests/log_retention_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/tests/utils/disk_log_builder.h" // fixture #include "test_utils/fixture.h" diff --git a/src/v/storage/tests/log_segment_appender_test.cc b/src/v/storage/tests/log_segment_appender_test.cc index bf2a300510de4..6624ee40b2337 100644 --- a/src/v/storage/tests/log_segment_appender_test.cc +++ b/src/v/storage/tests/log_segment_appender_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "random/generators.h" #include "seastarx.h" diff --git a/src/v/storage/tests/log_segment_reader_test.cc b/src/v/storage/tests/log_segment_reader_test.cc index 046c97517b9a2..6d33a0a0132e5 100644 --- a/src/v/storage/tests/log_segment_reader_test.cc +++ b/src/v/storage/tests/log_segment_reader_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record.h" #include "model/record_batch_reader.h" #include "model/record_utils.h" diff --git a/src/v/storage/tests/log_truncate_test.cc b/src/v/storage/tests/log_truncate_test.cc index b3b634c4a23a3..36ee66b6b70ea 100644 --- a/src/v/storage/tests/log_truncate_test.cc +++ b/src/v/storage/tests/log_truncate_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/fundamental.h" #include "model/record.h" #include "model/timestamp.h" diff --git a/src/v/storage/tests/offset_assignment_test.cc b/src/v/storage/tests/offset_assignment_test.cc index b063844395a77..b703abf779efa 100644 --- a/src/v/storage/tests/offset_assignment_test.cc +++ b/src/v/storage/tests/offset_assignment_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/offset_assignment.h" #include "storage/tests/utils/random_batch.h" diff --git a/src/v/storage/tests/offset_index_utils_tests.cc b/src/v/storage/tests/offset_index_utils_tests.cc index 259c7ea31e937..c19bbdfd320d1 100644 --- a/src/v/storage/tests/offset_index_utils_tests.cc +++ b/src/v/storage/tests/offset_index_utils_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf_file.h" #include "random/generators.h" #include "storage/segment_index.h" diff --git a/src/v/storage/tests/parser_test.cc b/src/v/storage/tests/parser_test.cc index 1f719177696bc..24ed882ef9d22 100644 --- a/src/v/storage/tests/parser_test.cc +++ b/src/v/storage/tests/parser_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/iobuf.h" #include "model/compression.h" #include "model/fundamental.h" diff --git a/src/v/storage/tests/produce_consume_test.cc b/src/v/storage/tests/produce_consume_test.cc index ff71acc55f4dd..441da0c779167 100644 --- a/src/v/storage/tests/produce_consume_test.cc +++ b/src/v/storage/tests/produce_consume_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "model/record_batch_reader.h" diff --git a/src/v/storage/tests/segment_size_jitter_test.cc b/src/v/storage/tests/segment_size_jitter_test.cc index 9748455c057bc..21f8d604f64ec 100644 --- a/src/v/storage/tests/segment_size_jitter_test.cc +++ b/src/v/storage/tests/segment_size_jitter_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/segment_utils.h" #include diff --git a/src/v/storage/tests/snapshot_test.cc b/src/v/storage/tests/snapshot_test.cc index 4771cd625f97f..3d3b279f14de5 100644 --- a/src/v/storage/tests/snapshot_test.cc +++ b/src/v/storage/tests/snapshot_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "random/generators.h" #include "seastarx.h" #include "storage/snapshot.h" diff --git a/src/v/storage/tests/storage_e2e_test.cc b/src/v/storage/tests/storage_e2e_test.cc index 18806317cb8b7..2cc5857f5f5c7 100644 --- a/src/v/storage/tests/storage_e2e_test.cc +++ b/src/v/storage/tests/storage_e2e_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/bytes.h" #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/storage/tests/storage_test_fixture.h b/src/v/storage/tests/storage_test_fixture.h index 7314134143acc..2f7244f467ee9 100644 --- a/src/v/storage/tests/storage_test_fixture.h +++ b/src/v/storage/tests/storage_test_fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "hashing/crc32c.h" diff --git a/src/v/storage/tests/timequery_test.cc b/src/v/storage/tests/timequery_test.cc index 289e7352b227b..82733302316ad 100644 --- a/src/v/storage/tests/timequery_test.cc +++ b/src/v/storage/tests/timequery_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/tests/disk_log_builder_fixture.h" #include "storage/tests/utils/random_batch.h" #include "test_utils/fixture.h" diff --git a/src/v/storage/tests/utils/disk_log_builder.cc b/src/v/storage/tests/utils/disk_log_builder.cc index d5b7cf9ba395e..a5ba8e31a5916 100644 --- a/src/v/storage/tests/utils/disk_log_builder.cc +++ b/src/v/storage/tests/utils/disk_log_builder.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/tests/utils/disk_log_builder.h" #include "storage/disk_log_appender.h" diff --git a/src/v/storage/tests/utils/disk_log_builder.h b/src/v/storage/tests/utils/disk_log_builder.h index 1dd71e116480b..f1b0d7208feaa 100644 --- a/src/v/storage/tests/utils/disk_log_builder.h +++ b/src/v/storage/tests/utils/disk_log_builder.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/record.h" diff --git a/src/v/storage/tests/utils/random_batch.cc b/src/v/storage/tests/utils/random_batch.cc index eb60a32edd88c..a153e37ef39fb 100644 --- a/src/v/storage/tests/utils/random_batch.cc +++ b/src/v/storage/tests/utils/random_batch.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/tests/utils/random_batch.h" #include "bytes/iobuf.h" diff --git a/src/v/storage/tests/utils/random_batch.h b/src/v/storage/tests/utils/random_batch.h index 16a504b19c325..7a562351285dd 100644 --- a/src/v/storage/tests/utils/random_batch.h +++ b/src/v/storage/tests/utils/random_batch.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/record.h" diff --git a/src/v/storage/types.cc b/src/v/storage/types.cc index 51cc0915bcd6a..96f65e345d36c 100644 --- a/src/v/storage/types.cc +++ b/src/v/storage/types.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "storage/types.h" #include "utils/to_string.h" diff --git a/src/v/storage/types.h b/src/v/storage/types.h index be0922f83c34a..cf47b40fb798e 100644 --- a/src/v/storage/types.h +++ b/src/v/storage/types.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" diff --git a/src/v/storage/version.h b/src/v/storage/version.h index 389d195d466f6..6736b888bcbc9 100644 --- a/src/v/storage/version.h +++ b/src/v/storage/version.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/syschecks/pidfile.cc b/src/v/syschecks/pidfile.cc index 91dc01c5112a1..dde26f4fc3466 100644 --- a/src/v/syschecks/pidfile.cc +++ b/src/v/syschecks/pidfile.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "seastarx.h" #include "syschecks/syschecks.h" #include "vassert.h" diff --git a/src/v/syschecks/syschecks.cc b/src/v/syschecks/syschecks.cc index 146f74b099153..d4485971b5f07 100644 --- a/src/v/syschecks/syschecks.cc +++ b/src/v/syschecks/syschecks.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "syschecks/syschecks.h" #include "likely.h" diff --git a/src/v/syschecks/syschecks.h b/src/v/syschecks/syschecks.h index 90abf7c6ce167..a0695cf4ce854 100644 --- a/src/v/syschecks/syschecks.h +++ b/src/v/syschecks/syschecks.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/test_utils/async.h b/src/v/test_utils/async.h index 9a9ab40388c6a..cac21e458f001 100644 --- a/src/v/test_utils/async.h +++ b/src/v/test_utils/async.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/timeout_clock.h" #include "seastarx.h" diff --git a/src/v/test_utils/fixture.h b/src/v/test_utils/fixture.h index e061f036b9685..4e39df0693165 100644 --- a/src/v/test_utils/fixture.h +++ b/src/v/test_utils/fixture.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/test_utils/logs.h b/src/v/test_utils/logs.h index 54494e1fdfad3..df137ef078454 100644 --- a/src/v/test_utils/logs.h +++ b/src/v/test_utils/logs.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/fundamental.h" #include "model/record_batch_reader.h" diff --git a/src/v/test_utils/non_root_port.h b/src/v/test_utils/non_root_port.h index 91941084de7f1..014deaabce99f 100644 --- a/src/v/test_utils/non_root_port.h +++ b/src/v/test_utils/non_root_port.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once inline uint16_t non_root_port(uint16_t port) { if (port < 1024) return port + 1024; diff --git a/src/v/test_utils/randoms.h b/src/v/test_utils/randoms.h index c85c817e539ce..d3abb4fb2ea68 100644 --- a/src/v/test_utils/randoms.h +++ b/src/v/test_utils/randoms.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "model/metadata.h" #include "random/generators.h" diff --git a/src/v/test_utils/rpc.h b/src/v/test_utils/rpc.h index c6a2884183a44..c1d358098f78b 100644 --- a/src/v/test_utils/rpc.h +++ b/src/v/test_utils/rpc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "reflection/adl.h" #include "reflection/async_adl.h" diff --git a/src/v/test_utils/seastar_testing_main.cc b/src/v/test_utils/seastar_testing_main.cc index 41b53d420d351..b3fd7a869a9fe 100644 --- a/src/v/test_utils/seastar_testing_main.cc +++ b/src/v/test_utils/seastar_testing_main.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define SEASTAR_TESTING_MAIN #include diff --git a/src/v/tristate.h b/src/v/tristate.h index 6c03eefc11469..b90c0d1b196c1 100644 --- a/src/v/tristate.h +++ b/src/v/tristate.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/units.h b/src/v/units.h index aa495bcd7315c..6a23f5ce4e72e 100644 --- a/src/v/units.h +++ b/src/v/units.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/concepts-enabled.h b/src/v/utils/concepts-enabled.h index e0e35640e24c3..0ea900bf4e2b7 100644 --- a/src/v/utils/concepts-enabled.h +++ b/src/v/utils/concepts-enabled.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/copy_range.h b/src/v/utils/copy_range.h index ca3a78fb3f6e2..48ec84db6c991 100644 --- a/src/v/utils/copy_range.h +++ b/src/v/utils/copy_range.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/directory_walker.h b/src/v/utils/directory_walker.h index d3ce255d99c44..1e03c22ffca3c 100644 --- a/src/v/utils/directory_walker.h +++ b/src/v/utils/directory_walker.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/expiring_promise.h b/src/v/utils/expiring_promise.h index 718a2475e31de..fbf0066a05cd3 100644 --- a/src/v/utils/expiring_promise.h +++ b/src/v/utils/expiring_promise.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/file_io.h b/src/v/utils/file_io.h index 3629e2531e313..cea0b76e01117 100644 --- a/src/v/utils/file_io.h +++ b/src/v/utils/file_io.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/utils/file_sanitizer.h b/src/v/utils/file_sanitizer.h index 66f34f9b91d24..d6acfbce6ff6b 100644 --- a/src/v/utils/file_sanitizer.h +++ b/src/v/utils/file_sanitizer.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "vassert.h" diff --git a/src/v/utils/hdr_hist.cc b/src/v/utils/hdr_hist.cc index c366afe9a7dfd..c696b6bc0295f 100644 --- a/src/v/utils/hdr_hist.cc +++ b/src/v/utils/hdr_hist.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "utils/hdr_hist.h" #include "likely.h" diff --git a/src/v/utils/hdr_hist.h b/src/v/utils/hdr_hist.h index c2777a5b5cb9d..214a329ee9538 100644 --- a/src/v/utils/hdr_hist.h +++ b/src/v/utils/hdr_hist.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once // Must include first for a seastar transitive type only on GCC diff --git a/src/v/utils/human.cc b/src/v/utils/human.cc index 60a9311dfdb95..c82661a9041da 100644 --- a/src/v/utils/human.cc +++ b/src/v/utils/human.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "utils/human.h" #include "seastarx.h" diff --git a/src/v/utils/human.h b/src/v/utils/human.h index b072fa2f01515..02fd14df1a30e 100644 --- a/src/v/utils/human.h +++ b/src/v/utils/human.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/intrusive_list_helpers.h b/src/v/utils/intrusive_list_helpers.h index 14d1c7c4ea7a0..665d763a3dd41 100644 --- a/src/v/utils/intrusive_list_helpers.h +++ b/src/v/utils/intrusive_list_helpers.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once /* diff --git a/src/v/utils/memory_data_source.h b/src/v/utils/memory_data_source.h index 5a6564e4eb388..c7dfbbc908d12 100644 --- a/src/v/utils/memory_data_source.h +++ b/src/v/utils/memory_data_source.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/mutex.h b/src/v/utils/mutex.h index f8c9cf44177cd..5229a1b2cdc56 100644 --- a/src/v/utils/mutex.h +++ b/src/v/utils/mutex.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/named_type.h b/src/v/utils/named_type.h index 55a18fd2079c1..91a913f65b3de 100644 --- a/src/v/utils/named_type.h +++ b/src/v/utils/named_type.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/remote.h b/src/v/utils/remote.h index 220fbc55cd2a3..61cb8871415bd 100644 --- a/src/v/utils/remote.h +++ b/src/v/utils/remote.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/utils/retry.h b/src/v/utils/retry.h index 0866a50fa9268..58f525d07f4fe 100644 --- a/src/v/utils/retry.h +++ b/src/v/utils/retry.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" #include "utils/concepts-enabled.h" diff --git a/src/v/utils/state_crc_file.cc b/src/v/utils/state_crc_file.cc index 27100871c87fa..6de5897ad8ce6 100644 --- a/src/v/utils/state_crc_file.cc +++ b/src/v/utils/state_crc_file.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "utils/state_crc_file.h" #include "hashing/crc32c.h" diff --git a/src/v/utils/state_crc_file.h b/src/v/utils/state_crc_file.h index 0c5cf3c5dc1fa..83ef3f2fa55bd 100644 --- a/src/v/utils/state_crc_file.h +++ b/src/v/utils/state_crc_file.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/iobuf.h" diff --git a/src/v/utils/state_crc_file_errc.h b/src/v/utils/state_crc_file_errc.h index e88f2b4495170..6e6400fc223d1 100644 --- a/src/v/utils/state_crc_file_errc.h +++ b/src/v/utils/state_crc_file_errc.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/string_switch.h b/src/v/utils/string_switch.h index 43059db388503..3c25aba056faf 100644 --- a/src/v/utils/string_switch.h +++ b/src/v/utils/string_switch.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/tests/constexpr_string_switch.cc b/src/v/utils/tests/constexpr_string_switch.cc index b4b7ae3166354..1ffb9dadb267e 100644 --- a/src/v/utils/tests/constexpr_string_switch.cc +++ b/src/v/utils/tests/constexpr_string_switch.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE utils #include "utils/string_switch.h" diff --git a/src/v/utils/tests/directory_walker_test.cc b/src/v/utils/tests/directory_walker_test.cc index 0c83b1a34bd76..603ed68e34d65 100644 --- a/src/v/utils/tests/directory_walker_test.cc +++ b/src/v/utils/tests/directory_walker_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "random/generators.h" #include "utils/directory_walker.h" diff --git a/src/v/utils/tests/named_type_tests.cc b/src/v/utils/tests/named_type_tests.cc index d052d650d5fea..682c2024da40d 100644 --- a/src/v/utils/tests/named_type_tests.cc +++ b/src/v/utils/tests/named_type_tests.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE utils #include "seastarx.h" diff --git a/src/v/utils/tests/outcome_utils_test.cc b/src/v/utils/tests/outcome_utils_test.cc index 0d9998d9851d0..924048b972b35 100644 --- a/src/v/utils/tests/outcome_utils_test.cc +++ b/src/v/utils/tests/outcome_utils_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "outcome_future_utils.h" #include diff --git a/src/v/utils/tests/remote_test.cc b/src/v/utils/tests/remote_test.cc index 0d0e2010db31c..9f615f1d1a2cf 100644 --- a/src/v/utils/tests/remote_test.cc +++ b/src/v/utils/tests/remote_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "utils/remote.h" #include diff --git a/src/v/utils/tests/retry_test.cc b/src/v/utils/tests/retry_test.cc index fc22c10739ad8..79c8cd9d1ac20 100644 --- a/src/v/utils/tests/retry_test.cc +++ b/src/v/utils/tests/retry_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "seastarx.h" #include "utils/retry.h" diff --git a/src/v/utils/tests/state_crc_file_test.cc b/src/v/utils/tests/state_crc_file_test.cc index 561f4722126cb..632982460457f 100644 --- a/src/v/utils/tests/state_crc_file_test.cc +++ b/src/v/utils/tests/state_crc_file_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "random/generators.h" #include "test_utils/fixture.h" #include "utils/state_crc_file.h" diff --git a/src/v/utils/tests/string_switch_test.cc b/src/v/utils/tests/string_switch_test.cc index a7ddc4e19a1d6..2b9eda8d98eb7 100644 --- a/src/v/utils/tests/string_switch_test.cc +++ b/src/v/utils/tests/string_switch_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE utils #include "utils/string_switch.h" diff --git a/src/v/utils/tests/tristate_test.cc b/src/v/utils/tests/tristate_test.cc index a53eb9ed362f1..19628e819507d 100644 --- a/src/v/utils/tests/tristate_test.cc +++ b/src/v/utils/tests/tristate_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #define BOOST_TEST_MODULE utils #include "tristate.h" diff --git a/src/v/utils/tests/vint_test.cc b/src/v/utils/tests/vint_test.cc index d29100cfbf3fe..7fc3be1c76223 100644 --- a/src/v/utils/tests/vint_test.cc +++ b/src/v/utils/tests/vint_test.cc @@ -1,3 +1,12 @@ +// Copyright 2020 Vectorized, Inc. +// +// Use of this software is governed by the Business Source License +// included in the file licenses/BSL.md +// +// As of the Change Date specified in that file, in accordance with +// the Business Source License, use of this software will be governed +// by the Apache License, Version 2.0 + #include "bytes/bytes.h" #include "utils/vint.h" diff --git a/src/v/utils/to_string.h b/src/v/utils/to_string.h index 660d22ba4d1a3..b7e3f5f1a0fd4 100644 --- a/src/v/utils/to_string.h +++ b/src/v/utils/to_string.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/unresolved_address.h b/src/v/utils/unresolved_address.h index 9771b1f04233d..7346f572cb001 100644 --- a/src/v/utils/unresolved_address.h +++ b/src/v/utils/unresolved_address.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "seastarx.h" diff --git a/src/v/utils/utf8.h b/src/v/utils/utf8.h index cb6006c8dd2e1..8df646c7ed232 100644 --- a/src/v/utils/utf8.h +++ b/src/v/utils/utf8.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/src/v/utils/vint.h b/src/v/utils/vint.h index b5ccbbe1c3b6c..ed8d37d3b5af5 100644 --- a/src/v/utils/vint.h +++ b/src/v/utils/vint.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "bytes/bytes.h" diff --git a/src/v/vassert.h b/src/v/vassert.h index fe16dfb589432..e3f267d07c4f1 100644 --- a/src/v/vassert.h +++ b/src/v/vassert.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include "likely.h" diff --git a/src/v/vlog.h b/src/v/vlog.h index c4ff99cc1ce43..ef46160e08ea0 100644 --- a/src/v/vlog.h +++ b/src/v/vlog.h @@ -1,3 +1,14 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Use of this software is governed by the Business Source License + * included in the file licenses/BSL.md + * + * As of the Change Date specified in that file, in accordance with + * the Business Source License, use of this software will be governed + * by the Apache License, Version 2.0 + */ + #pragma once #include diff --git a/tests/rptest/__init__.py b/tests/rptest/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/__init__.py +++ b/tests/rptest/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/chaos/__init__.py b/tests/rptest/chaos/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/chaos/__init__.py +++ b/tests/rptest/chaos/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/chaos/kafkakv_muservice.py b/tests/rptest/chaos/kafkakv_muservice.py index fceaf101794db..098353cc279b6 100644 --- a/tests/rptest/chaos/kafkakv_muservice.py +++ b/tests/rptest/chaos/kafkakv_muservice.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import signal import sys diff --git a/tests/rptest/chaos/mount_muservice.py b/tests/rptest/chaos/mount_muservice.py index 775f468913692..c526dd0c2b74e 100644 --- a/tests/rptest/chaos/mount_muservice.py +++ b/tests/rptest/chaos/mount_muservice.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import signal import sys diff --git a/tests/rptest/chaos/muservice.py b/tests/rptest/chaos/muservice.py index 621b4e67c1e84..897952d0264da 100644 --- a/tests/rptest/chaos/muservice.py +++ b/tests/rptest/chaos/muservice.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.services.service import Service diff --git a/tests/rptest/chaos/redpanda_duck_cluster.py b/tests/rptest/chaos/redpanda_duck_cluster.py index 0c363572b5f15..02911fa5c512d 100644 --- a/tests/rptest/chaos/redpanda_duck_cluster.py +++ b/tests/rptest/chaos/redpanda_duck_cluster.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import time import json import sys diff --git a/tests/rptest/chaos/redpanda_muservice.py b/tests/rptest/chaos/redpanda_muservice.py index cb57b4121ae30..0e05e5ade128e 100644 --- a/tests/rptest/chaos/redpanda_muservice.py +++ b/tests/rptest/chaos/redpanda_muservice.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import sys import traceback diff --git a/tests/rptest/chaos/templates/redpanda.yaml b/tests/rptest/chaos/templates/redpanda.yaml index 173f4ee86926f..e7cd7688b66c8 100644 --- a/tests/rptest/chaos/templates/redpanda.yaml +++ b/tests/rptest/chaos/templates/redpanda.yaml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + organization: "vectorized" cluster_id: "{{cluster}}" diff --git a/tests/rptest/clients/__init__.py b/tests/rptest/clients/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/clients/__init__.py +++ b/tests/rptest/clients/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/clients/compacted_verifier.py b/tests/rptest/clients/compacted_verifier.py index 5f40783cadf6e..a2081aafb462f 100644 --- a/tests/rptest/clients/compacted_verifier.py +++ b/tests/rptest/clients/compacted_verifier.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess diff --git a/tests/rptest/clients/kafka_cat.py b/tests/rptest/clients/kafka_cat.py index 74273fe13a4db..a8b3089c2b83b 100644 --- a/tests/rptest/clients/kafka_cat.py +++ b/tests/rptest/clients/kafka_cat.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess import time import json diff --git a/tests/rptest/clients/kafka_cli_tools.py b/tests/rptest/clients/kafka_cli_tools.py index 00a5776879c5d..97485997541f4 100644 --- a/tests/rptest/clients/kafka_cli_tools.py +++ b/tests/rptest/clients/kafka_cli_tools.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess diff --git a/tests/rptest/clients/rpk.py b/tests/rptest/clients/rpk.py index 63cb79ce95ec0..28efd6567e6a0 100644 --- a/tests/rptest/clients/rpk.py +++ b/tests/rptest/clients/rpk.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess import tempfile import time diff --git a/tests/rptest/services/__init__.py b/tests/rptest/services/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/services/__init__.py +++ b/tests/rptest/services/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/services/kaf_consumer.py b/tests/rptest/services/kaf_consumer.py index b1fee58a225f3..7403d2db6aaf4 100644 --- a/tests/rptest/services/kaf_consumer.py +++ b/tests/rptest/services/kaf_consumer.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import re from ducktape.services.background_thread import BackgroundThreadService diff --git a/tests/rptest/services/kaf_producer.py b/tests/rptest/services/kaf_producer.py index 3ffb33fed1da3..ff4991c391598 100644 --- a/tests/rptest/services/kaf_producer.py +++ b/tests/rptest/services/kaf_producer.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys from ducktape.services.background_thread import BackgroundThreadService diff --git a/tests/rptest/services/pandaproxy.py b/tests/rptest/services/pandaproxy.py index 50009a279fd9a..f1bb48be572c6 100644 --- a/tests/rptest/services/pandaproxy.py +++ b/tests/rptest/services/pandaproxy.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import signal diff --git a/tests/rptest/services/redpanda.py b/tests/rptest/services/redpanda.py index 92222b48be2c3..c1645119fddbd 100644 --- a/tests/rptest/services/redpanda.py +++ b/tests/rptest/services/redpanda.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import signal import tempfile diff --git a/tests/rptest/services/rpk_consumer.py b/tests/rptest/services/rpk_consumer.py index 72936a9e2a321..476b740dc5cec 100644 --- a/tests/rptest/services/rpk_consumer.py +++ b/tests/rptest/services/rpk_consumer.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import json from ducktape.services.background_thread import BackgroundThreadService diff --git a/tests/rptest/services/storage.py b/tests/rptest/services/storage.py index 59c471758dfaa..3112b7b9d76d9 100644 --- a/tests/rptest/services/storage.py +++ b/tests/rptest/services/storage.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import re import itertools diff --git a/tests/rptest/services/templates/pandaproxy.yaml b/tests/rptest/services/templates/pandaproxy.yaml index 33a15c35e1997..79befa063f108 100644 --- a/tests/rptest/services/templates/pandaproxy.yaml +++ b/tests/rptest/services/templates/pandaproxy.yaml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # Pandaproxy configuration file # organization and cluster_id help Vectorized identify your system. diff --git a/tests/rptest/services/templates/redpanda.yaml b/tests/rptest/services/templates/redpanda.yaml index bfa319a6c7024..016a2981f3942 100644 --- a/tests/rptest/services/templates/redpanda.yaml +++ b/tests/rptest/services/templates/redpanda.yaml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + organization: "vectorized" cluster_id: "{{cluster}}" diff --git a/tests/rptest/test_suite_all.yml b/tests/rptest/test_suite_all.yml index 02ad9de6a19a3..1b663b85629b2 100644 --- a/tests/rptest/test_suite_all.yml +++ b/tests/rptest/test_suite_all.yml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + all: included: - tests/ diff --git a/tests/rptest/test_suite_chaos.yml b/tests/rptest/test_suite_chaos.yml index 723415e15a0a1..23e3efcac51b3 100644 --- a/tests/rptest/test_suite_chaos.yml +++ b/tests/rptest/test_suite_chaos.yml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + chaos: included: - tests/chaos/ diff --git a/tests/rptest/test_suite_quick.yml b/tests/rptest/test_suite_quick.yml index a7231930169ad..d48efef5e5323 100644 --- a/tests/rptest/test_suite_quick.yml +++ b/tests/rptest/test_suite_quick.yml @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + quick: included: - tests/ diff --git a/tests/rptest/tests/__init__.py b/tests/rptest/tests/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/tests/__init__.py +++ b/tests/rptest/tests/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/tests/chaos/__init__.py b/tests/rptest/tests/chaos/__init__.py index e69de29bb2d1d..108bf650a86ee 100644 --- a/tests/rptest/tests/chaos/__init__.py +++ b/tests/rptest/tests/chaos/__init__.py @@ -0,0 +1,9 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + diff --git a/tests/rptest/tests/chaos/baseline_test.py b/tests/rptest/tests/chaos/baseline_test.py index 99d5b5306933d..6ad35e218c8e8 100644 --- a/tests/rptest/tests/chaos/baseline_test.py +++ b/tests/rptest/tests/chaos/baseline_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/chaos_base_test.py b/tests/rptest/tests/chaos/chaos_base_test.py index c4505360198ba..cdda60facc6f8 100644 --- a/tests/rptest/tests/chaos/chaos_base_test.py +++ b/tests/rptest/tests/chaos/chaos_base_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import time import pathlib import os diff --git a/tests/rptest/tests/chaos/isolate_follower_test.py b/tests/rptest/tests/chaos/isolate_follower_test.py index f8cf17f4e6303..c77a182faf152 100644 --- a/tests/rptest/tests/chaos/isolate_follower_test.py +++ b/tests/rptest/tests/chaos/isolate_follower_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/isolate_leader_test.py b/tests/rptest/tests/chaos/isolate_leader_test.py index 7bf27ad1755ff..17523b2f841e3 100644 --- a/tests/rptest/tests/chaos/isolate_leader_test.py +++ b/tests/rptest/tests/chaos/isolate_leader_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/ruinio_follower_test.py b/tests/rptest/tests/chaos/ruinio_follower_test.py index b578804d727d4..8f9a0b895b25b 100644 --- a/tests/rptest/tests/chaos/ruinio_follower_test.py +++ b/tests/rptest/tests/chaos/ruinio_follower_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/ruinio_leader_test.py b/tests/rptest/tests/chaos/ruinio_leader_test.py index 4ac18a88389f2..c660476ec76e2 100644 --- a/tests/rptest/tests/chaos/ruinio_leader_test.py +++ b/tests/rptest/tests/chaos/ruinio_leader_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/slowio_follower_test.py b/tests/rptest/tests/chaos/slowio_follower_test.py index e02f1d30feece..5f32d8d9cfdd6 100644 --- a/tests/rptest/tests/chaos/slowio_follower_test.py +++ b/tests/rptest/tests/chaos/slowio_follower_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/slowio_leader_test.py b/tests/rptest/tests/chaos/slowio_leader_test.py index ff474620ff41a..f4dbf07c6dd8b 100644 --- a/tests/rptest/tests/chaos/slowio_leader_test.py +++ b/tests/rptest/tests/chaos/slowio_leader_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/suspend_follower_test.py b/tests/rptest/tests/chaos/suspend_follower_test.py index 5955dc2b5c7e8..78f29db9fc6da 100644 --- a/tests/rptest/tests/chaos/suspend_follower_test.py +++ b/tests/rptest/tests/chaos/suspend_follower_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/suspend_leader_test.py b/tests/rptest/tests/chaos/suspend_leader_test.py index 633ccab1f30fe..2fb7e1cb8b10f 100644 --- a/tests/rptest/tests/chaos/suspend_leader_test.py +++ b/tests/rptest/tests/chaos/suspend_leader_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/terminate_follower_test.py b/tests/rptest/tests/chaos/terminate_follower_test.py index ad4cdd39336b4..109323344697f 100644 --- a/tests/rptest/tests/chaos/terminate_follower_test.py +++ b/tests/rptest/tests/chaos/terminate_follower_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/chaos/terminate_leader_test.py b/tests/rptest/tests/chaos/terminate_leader_test.py index 35f8bf8e947a2..b30b410cf2aeb 100644 --- a/tests/rptest/tests/chaos/terminate_leader_test.py +++ b/tests/rptest/tests/chaos/terminate_leader_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys sys.path.append("/opt/v/src/consistency-testing/gobekli") sys.path.append("/opt/v/src/consistency-testing/chaostest") diff --git a/tests/rptest/tests/compacted_term_rolled_recovery_test.py b/tests/rptest/tests/compacted_term_rolled_recovery_test.py index 49a42433a975c..2670cea904452 100644 --- a/tests/rptest/tests/compacted_term_rolled_recovery_test.py +++ b/tests/rptest/tests/compacted_term_rolled_recovery_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until diff --git a/tests/rptest/tests/compacted_topic_verifier_test.py b/tests/rptest/tests/compacted_topic_verifier_test.py index 640dfca9900f0..d6486f0ad80a5 100644 --- a/tests/rptest/tests/compacted_topic_verifier_test.py +++ b/tests/rptest/tests/compacted_topic_verifier_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until from ducktape.errors import DucktapeError diff --git a/tests/rptest/tests/compaction_recovery_test.py b/tests/rptest/tests/compaction_recovery_test.py index 4a3615b839aa2..a2498885875d7 100644 --- a/tests/rptest/tests/compaction_recovery_test.py +++ b/tests/rptest/tests/compaction_recovery_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until diff --git a/tests/rptest/tests/configuration_update_test.py b/tests/rptest/tests/configuration_update_test.py index 9742bdaf12107..9260b4566bbb8 100644 --- a/tests/rptest/tests/configuration_update_test.py +++ b/tests/rptest/tests/configuration_update_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until diff --git a/tests/rptest/tests/controller_recovery_test.py b/tests/rptest/tests/controller_recovery_test.py index 5b9b6c0b2ccce..66b90f6acb037 100644 --- a/tests/rptest/tests/controller_recovery_test.py +++ b/tests/rptest/tests/controller_recovery_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until diff --git a/tests/rptest/tests/demo_test.py b/tests/rptest/tests/demo_test.py index 2c396bc952a04..afe6b634e7417 100644 --- a/tests/rptest/tests/demo_test.py +++ b/tests/rptest/tests/demo_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess import os diff --git a/tests/rptest/tests/describe_topics_test.py b/tests/rptest/tests/describe_topics_test.py index 8bf4bf608602e..3a99f6ada8a3c 100644 --- a/tests/rptest/tests/describe_topics_test.py +++ b/tests/rptest/tests/describe_topics_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark import matrix from rptest.tests.redpanda_test import RedpandaTest diff --git a/tests/rptest/tests/kafka_cli_tools_test.py b/tests/rptest/tests/kafka_cli_tools_test.py index 093b2dddcb806..3df6a87174e62 100644 --- a/tests/rptest/tests/kafka_cli_tools_test.py +++ b/tests/rptest/tests/kafka_cli_tools_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark import matrix from rptest.tests.redpanda_test import RedpandaTest diff --git a/tests/rptest/tests/leadership_transfer_test.py b/tests/rptest/tests/leadership_transfer_test.py index f895d794df5ce..b891ebaee25ba 100644 --- a/tests/rptest/tests/leadership_transfer_test.py +++ b/tests/rptest/tests/leadership_transfer_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import random import time diff --git a/tests/rptest/tests/librdkafka_test.py b/tests/rptest/tests/librdkafka_test.py index 7c22426a5ef39..5adbf340e962b 100644 --- a/tests/rptest/tests/librdkafka_test.py +++ b/tests/rptest/tests/librdkafka_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import subprocess import os import time diff --git a/tests/rptest/tests/pandaproxy_test.py b/tests/rptest/tests/pandaproxy_test.py index 67545a71b3033..abb69d36a7f4e 100644 --- a/tests/rptest/tests/pandaproxy_test.py +++ b/tests/rptest/tests/pandaproxy_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import json import uuid import requests diff --git a/tests/rptest/tests/prefix_truncate_recovery_test.py b/tests/rptest/tests/prefix_truncate_recovery_test.py index 7cabdeff04dcf..4e975e698c8bd 100644 --- a/tests/rptest/tests/prefix_truncate_recovery_test.py +++ b/tests/rptest/tests/prefix_truncate_recovery_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import os import collections import tempfile diff --git a/tests/rptest/tests/produce_bench_test.py b/tests/rptest/tests/produce_bench_test.py index 6ce8cc98dff09..a992c87adf533 100644 --- a/tests/rptest/tests/produce_bench_test.py +++ b/tests/rptest/tests/produce_bench_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # taken from https://github.com/apache/kafka @ 9368743 import json diff --git a/tests/rptest/tests/redpanda_test.py b/tests/rptest/tests/redpanda_test.py index 146b7662db34f..24c0cb954a813 100644 --- a/tests/rptest/tests/redpanda_test.py +++ b/tests/rptest/tests/redpanda_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.tests.test import Test from rptest.services.redpanda import RedpandaService diff --git a/tests/rptest/tests/rpk_test.py b/tests/rptest/tests/rpk_test.py index 0c4ed560fc7d0..e9053d7311eaf 100644 --- a/tests/rptest/tests/rpk_test.py +++ b/tests/rptest/tests/rpk_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.utils.util import wait_until from rptest.tests.redpanda_test import RedpandaTest diff --git a/tests/rptest/tests/topic_delete_test.py b/tests/rptest/tests/topic_delete_test.py index 759383492ac2e..528983f6db974 100644 --- a/tests/rptest/tests/topic_delete_test.py +++ b/tests/rptest/tests/topic_delete_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import collections from ducktape.mark.resource import cluster diff --git a/tests/rptest/tests/wait_for_local_consumer_test.py b/tests/rptest/tests/wait_for_local_consumer_test.py index b9a7b6a1bf758..88f73719b0830 100644 --- a/tests/rptest/tests/wait_for_local_consumer_test.py +++ b/tests/rptest/tests/wait_for_local_consumer_test.py @@ -1,3 +1,12 @@ +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + from ducktape.mark.resource import cluster from ducktape.utils.util import wait_until diff --git a/tools/cmake_test.py b/tools/cmake_test.py index fd44d6dfc464f..96cf01aff3344 100755 --- a/tools/cmake_test.py +++ b/tools/cmake_test.py @@ -1,4 +1,13 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys import os import logging diff --git a/tools/kafka-python-api-serde.py b/tools/kafka-python-api-serde.py index d0b9f1c93dcaa..e97bbe5f70316 100755 --- a/tools/kafka-python-api-serde.py +++ b/tools/kafka-python-api-serde.py @@ -1,4 +1,13 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + # # pip install kafka-python # diff --git a/tools/rpcgen.py b/tools/rpcgen.py index 959ae3a13d6c4..ac6208e51af5b 100755 --- a/tools/rpcgen.py +++ b/tools/rpcgen.py @@ -1,4 +1,13 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Use of this software is governed by the Business Source License +# included in the file licenses/BSL.md +# +# As of the Change Date specified in that file, in accordance with +# the Business Source License, use of this software will be governed +# by the Apache License, Version 2.0 + import sys import os import logging From 54a9a4a7b5512ff24b9454671a8761a48b447791 Mon Sep 17 00:00:00 2001 From: Alexander Gallego Date: Wed, 11 Nov 2020 23:27:34 -0800 Subject: [PATCH 3/4] licenses: add enterprise header for source files --- licenses/rcl_header.txt | 7 +++++++ 1 file changed, 7 insertions(+) create mode 100644 licenses/rcl_header.txt diff --git a/licenses/rcl_header.txt b/licenses/rcl_header.txt new file mode 100644 index 0000000000000..c8173acfb76d9 --- /dev/null +++ b/licenses/rcl_header.txt @@ -0,0 +1,7 @@ +Copyright 2020 Vectorized, Inc. + +Licensed as a Redpanda Enterprise file under the Redpanda Community +License (the "License"); you may not use this file except in compliance with +the License. You may obtain a copy of the License at + +https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md From 4535157110db24fd713be84b01c6a2a678faa6de Mon Sep 17 00:00:00 2001 From: Alexander Gallego Date: Wed, 11 Nov 2020 23:29:44 -0800 Subject: [PATCH 4/4] licenses: add redpanda community license headers --- src/js/compact-public.js | 10 ++++++++++ src/js/generate-entries.sh | 8 ++++++++ src/js/modules/domain/Handle.ts | 10 ++++++++++ src/js/modules/hashing/crc32.ts | 10 ++++++++++ src/js/modules/hashing/xxhash.ts | 10 ++++++++++ src/js/modules/public/Coprocessor.ts | 10 ++++++++++ src/js/modules/public/SimpleTransform.ts | 10 ++++++++++ src/js/modules/public/Utils.ts | 10 ++++++++++ src/js/modules/public/index.ts | 10 ++++++++++ src/js/modules/rpc/parser.ts | 10 ++++++++++ src/js/modules/rpc/server.ts | 10 ++++++++++ src/js/modules/rpc/service.ts | 10 ++++++++++ src/js/modules/rpc/types.ts | 10 ++++++++++ src/js/modules/supervisors/FileManager.ts | 10 ++++++++++ src/js/modules/supervisors/HandleTable.ts | 10 ++++++++++ src/js/modules/supervisors/Repository.ts | 10 ++++++++++ src/js/modules/utilities/Checksum.ts | 10 ++++++++++ src/js/modules/utilities/IOBuf.ts | 10 ++++++++++ src/js/modules/utilities/Map.ts | 10 ++++++++++ src/js/test/rpc/roundtrip.ts | 10 ++++++++++ src/js/test/rpc/server.test.ts | 10 ++++++++++ src/js/test/supervisors/FileManager.test.ts | 10 ++++++++++ src/js/test/supervisors/Repository.test.ts | 10 ++++++++++ src/js/test/testUtilities.ts | 10 ++++++++++ src/js/test/utilities/Checksum.test.ts | 10 ++++++++++ src/js/test/utilities/CoprocessorTest.ts | 10 ++++++++++ src/js/test/utilities/iobuf.test.ts | 10 ++++++++++ src/v/coproc/errc.h | 10 ++++++++++ src/v/coproc/logger.cc | 8 ++++++++ src/v/coproc/logger.h | 10 ++++++++++ src/v/coproc/router.cc | 8 ++++++++ src/v/coproc/router.h | 10 ++++++++++ src/v/coproc/service.cc | 8 ++++++++ src/v/coproc/service.h | 10 ++++++++++ src/v/coproc/tests/coproc_fixture_base.cc | 8 ++++++++ src/v/coproc/tests/coproc_fixture_base.h | 10 ++++++++++ src/v/coproc/tests/coproc_test_fixture.h | 10 ++++++++++ src/v/coproc/tests/coprocessor.h | 10 ++++++++++ src/v/coproc/tests/materialized_type_test.cc | 8 ++++++++ src/v/coproc/tests/router_test.cc | 8 ++++++++ src/v/coproc/tests/script_manager_service_test.cc | 8 ++++++++ src/v/coproc/tests/supervisor.cc | 8 ++++++++ src/v/coproc/tests/supervisor.h | 10 ++++++++++ src/v/coproc/tests/two_way_split_copro.h | 10 ++++++++++ src/v/coproc/tests/utils.cc | 8 ++++++++ src/v/coproc/tests/utils.h | 10 ++++++++++ src/v/coproc/types.cc | 8 ++++++++ src/v/coproc/types.h | 10 ++++++++++ tools/ts-generator/example/demo.ts | 10 ++++++++++ tools/ts-generator/example/functions.ts | 10 ++++++++++ tools/ts-generator/example/generated.ts | 10 ++++++++++ tools/ts-generator/rpc/example/demo.ts | 10 ++++++++++ tools/ts-generator/rpc/example/functions.ts | 10 ++++++++++ tools/ts-generator/rpc/example/generatedServer.ts | 10 ++++++++++ tools/ts-generator/rpc/example/generatedType.ts | 10 ++++++++++ tools/ts-generator/rpc/rpc_gen_js.py | 8 ++++++++ tools/ts-generator/types/functions.ts | 10 ++++++++++ tools/ts-generator/types/test.ts | 10 ++++++++++ tools/ts-generator/types/types_gen_js.py | 8 ++++++++ 59 files changed, 564 insertions(+) diff --git a/src/js/compact-public.js b/src/js/compact-public.js index 3d94f6801ba38..94dc5fc312b9f 100755 --- a/src/js/compact-public.js +++ b/src/js/compact-public.js @@ -1,4 +1,14 @@ #!/usr/bin/env node +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + const webpack = require("webpack"); const path = require("path"); diff --git a/src/js/generate-entries.sh b/src/js/generate-entries.sh index e3a7fd304b9ae..08ae5f77ccf27 100755 --- a/src/js/generate-entries.sh +++ b/src/js/generate-entries.sh @@ -1,4 +1,12 @@ #!/usr/bin/env bash +# Copyright 2020 Vectorized, Inc. +# +# Licensed as a Redpanda Enterprise file under the Redpanda Community +# License (the "License"); you may not use this file except in compliance with +# the License. You may obtain a copy of the License at +# +# https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + root=$(git rev-parse --show-toplevel) cd "$root"/tools/ts-generator/types && python types_gen_js.py \ diff --git a/src/js/modules/domain/Handle.ts b/src/js/modules/domain/Handle.ts index 957f3d18d7798..d9dc0257cb1de 100644 --- a/src/js/modules/domain/Handle.ts +++ b/src/js/modules/domain/Handle.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Coprocessor } from "../public/Coprocessor"; /** diff --git a/src/js/modules/hashing/crc32.ts b/src/js/modules/hashing/crc32.ts index e4a7c0b539114..a1d5191a566c0 100644 --- a/src/js/modules/hashing/crc32.ts +++ b/src/js/modules/hashing/crc32.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { calculate } from "fast-crc32c"; import { RecordBatchHeader, Record, RecordBatch } from "../rpc/types"; diff --git a/src/js/modules/hashing/xxhash.ts b/src/js/modules/hashing/xxhash.ts index bdb298c28b810..f08aef4e10b45 100644 --- a/src/js/modules/hashing/xxhash.ts +++ b/src/js/modules/hashing/xxhash.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { XXHash64 } from "xxhash"; export function RpcXxhash64(data: Buffer) { diff --git a/src/js/modules/public/Coprocessor.ts b/src/js/modules/public/Coprocessor.ts index b443ba4983594..25b01a5a10705 100644 --- a/src/js/modules/public/Coprocessor.ts +++ b/src/js/modules/public/Coprocessor.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + /** * Policy Error define what does the coprocessor function * do when the apply function into Coprocessor class fail. diff --git a/src/js/modules/public/SimpleTransform.ts b/src/js/modules/public/SimpleTransform.ts index df62b11128cd5..c54550749af78 100644 --- a/src/js/modules/public/SimpleTransform.ts +++ b/src/js/modules/public/SimpleTransform.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { RecordBatch, Coprocessor, PolicyError } from "./Coprocessor"; export class SimpleTransform implements Coprocessor { diff --git a/src/js/modules/public/Utils.ts b/src/js/modules/public/Utils.ts index 8845ab75670c7..757e2b8e2602d 100644 --- a/src/js/modules/public/Utils.ts +++ b/src/js/modules/public/Utils.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Record, RecordBatch, diff --git a/src/js/modules/public/index.ts b/src/js/modules/public/index.ts index ebda66f728f4b..27d3ad0c4536a 100644 --- a/src/js/modules/public/index.ts +++ b/src/js/modules/public/index.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { SimpleTransform } from "./SimpleTransform"; import { PolicyError } from "./Coprocessor"; import { createRecordBatch } from "./Utils"; diff --git a/src/js/modules/rpc/parser.ts b/src/js/modules/rpc/parser.ts index 6b213ca96d022..68512dc844804 100644 --- a/src/js/modules/rpc/parser.ts +++ b/src/js/modules/rpc/parser.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { RpcHeader, SimplePod, diff --git a/src/js/modules/rpc/server.ts b/src/js/modules/rpc/server.ts index a2840b1030f92..97284f6be4518 100644 --- a/src/js/modules/rpc/server.ts +++ b/src/js/modules/rpc/server.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import Repository from "../supervisors/Repository"; import FileManager from "../supervisors/FileManager"; import { Coprocessor, PolicyError } from "../public/Coprocessor"; diff --git a/src/js/modules/rpc/service.ts b/src/js/modules/rpc/service.ts index 348f1d0fa2436..32b698898d2ef 100644 --- a/src/js/modules/rpc/service.ts +++ b/src/js/modules/rpc/service.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { ProcessBatchServer } from "./server"; import { safeLoadAll } from "js-yaml"; import { join, resolve } from "path"; diff --git a/src/js/modules/rpc/types.ts b/src/js/modules/rpc/types.ts index f8e8cfe93826b..bf6b08bd7f167 100644 --- a/src/js/modules/rpc/types.ts +++ b/src/js/modules/rpc/types.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import * as bytes from "buffer"; export class SimplePod { diff --git a/src/js/modules/supervisors/FileManager.ts b/src/js/modules/supervisors/FileManager.ts index f98910c5d5b34..68593b903cd6e 100644 --- a/src/js/modules/supervisors/FileManager.ts +++ b/src/js/modules/supervisors/FileManager.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import * as Inotify from "inotifywait"; import { rename, readdir } from "fs"; import { promisify } from "util"; diff --git a/src/js/modules/supervisors/HandleTable.ts b/src/js/modules/supervisors/HandleTable.ts index e69de29bb2d1d..c9a1f6d2466ab 100644 --- a/src/js/modules/supervisors/HandleTable.ts +++ b/src/js/modules/supervisors/HandleTable.ts @@ -0,0 +1,10 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + diff --git a/src/js/modules/supervisors/Repository.ts b/src/js/modules/supervisors/Repository.ts index 8ccf135fcd854..6bc1f945e22b9 100644 --- a/src/js/modules/supervisors/Repository.ts +++ b/src/js/modules/supervisors/Repository.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Handle } from "../domain/Handle"; import { Coprocessor } from "../public/Coprocessor"; import { diff --git a/src/js/modules/utilities/Checksum.ts b/src/js/modules/utilities/Checksum.ts index 153344dd7cadb..633a833219074 100644 --- a/src/js/modules/utilities/Checksum.ts +++ b/src/js/modules/utilities/Checksum.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { createHash } from "crypto"; import { createReadStream } from "fs"; diff --git a/src/js/modules/utilities/IOBuf.ts b/src/js/modules/utilities/IOBuf.ts index 663f857d10d3d..606f722e800b8 100644 --- a/src/js/modules/utilities/IOBuf.ts +++ b/src/js/modules/utilities/IOBuf.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + type WriteInt = ( buf: Buffer, value: number | bigint, diff --git a/src/js/modules/utilities/Map.ts b/src/js/modules/utilities/Map.ts index bee478580c25c..94b4c4bf364fe 100644 --- a/src/js/modules/utilities/Map.ts +++ b/src/js/modules/utilities/Map.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + export const find = function ( map: Map, fn: (key: A, value: B) => boolean diff --git a/src/js/test/rpc/roundtrip.ts b/src/js/test/rpc/roundtrip.ts index a5b0b8d5dffd9..8dfc8be0294be 100644 --- a/src/js/test/rpc/roundtrip.ts +++ b/src/js/test/rpc/roundtrip.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { strict as assert } from "assert"; import { Serializer, Deserializer } from "../../modules/rpc/parser"; import { diff --git a/src/js/test/rpc/server.test.ts b/src/js/test/rpc/server.test.ts index 1b318361986f3..5816b500507d6 100644 --- a/src/js/test/rpc/server.test.ts +++ b/src/js/test/rpc/server.test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { ProcessBatchServer } from "../../modules/rpc/server"; import Repository from "../../modules/supervisors/Repository"; import { reset, stub } from "sinon"; diff --git a/src/js/test/supervisors/FileManager.test.ts b/src/js/test/supervisors/FileManager.test.ts index c3a1c16245a85..598bb08ac8823 100644 --- a/src/js/test/supervisors/FileManager.test.ts +++ b/src/js/test/supervisors/FileManager.test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import * as assert from "assert"; import { stub, spy, reset } from "sinon"; import FileManager from "../../modules/supervisors/FileManager"; diff --git a/src/js/test/supervisors/Repository.test.ts b/src/js/test/supervisors/Repository.test.ts index e2bcbb68f8b33..bcad7d75a9cdc 100644 --- a/src/js/test/supervisors/Repository.test.ts +++ b/src/js/test/supervisors/Repository.test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import * as assert from "assert"; import Repository from "../../modules/supervisors/Repository"; diff --git a/src/js/test/testUtilities.ts b/src/js/test/testUtilities.ts index 30a24458cea8d..5e7b6810a34de 100644 --- a/src/js/test/testUtilities.ts +++ b/src/js/test/testUtilities.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Coprocessor, PolicyError } from "../modules/public/Coprocessor"; import { Handle } from "../modules/domain/Handle"; import { createRecordBatch } from "../modules/public/"; diff --git a/src/js/test/utilities/Checksum.test.ts b/src/js/test/utilities/Checksum.test.ts index 2d398f83cad7e..65ee1f1249b86 100644 --- a/src/js/test/utilities/Checksum.test.ts +++ b/src/js/test/utilities/Checksum.test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { getChecksumFromFile } from "../../modules/utilities/Checksum"; import * as assert from "assert"; import { join } from "path"; diff --git a/src/js/test/utilities/CoprocessorTest.ts b/src/js/test/utilities/CoprocessorTest.ts index bacd3072b0cb5..43822144cc76f 100644 --- a/src/js/test/utilities/CoprocessorTest.ts +++ b/src/js/test/utilities/CoprocessorTest.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Coprocessor, RecordBatch, diff --git a/src/js/test/utilities/iobuf.test.ts b/src/js/test/utilities/iobuf.test.ts index 121193b6616f4..5119f2e916cc3 100644 --- a/src/js/test/utilities/iobuf.test.ts +++ b/src/js/test/utilities/iobuf.test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { FragmentIterator, fragmentSizes, diff --git a/src/v/coproc/errc.h b/src/v/coproc/errc.h index 069ab8a572634..ffda83911e8af 100644 --- a/src/v/coproc/errc.h +++ b/src/v/coproc/errc.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include diff --git a/src/v/coproc/logger.cc b/src/v/coproc/logger.cc index 436ec55df8b88..04b2879b81ccb 100644 --- a/src/v/coproc/logger.cc +++ b/src/v/coproc/logger.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "logger.h" namespace coproc { diff --git a/src/v/coproc/logger.h b/src/v/coproc/logger.h index 97f357700696e..e6504e5e9f70a 100644 --- a/src/v/coproc/logger.h +++ b/src/v/coproc/logger.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "seastarx.h" diff --git a/src/v/coproc/router.cc b/src/v/coproc/router.cc index c33f377e3a9c3..47259e5bc056f 100644 --- a/src/v/coproc/router.cc +++ b/src/v/coproc/router.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/router.h" #include "coproc/logger.h" diff --git a/src/v/coproc/router.h b/src/v/coproc/router.h index 69a11f81de7ce..774cfaddd5423 100644 --- a/src/v/coproc/router.h +++ b/src/v/coproc/router.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/errc.h" #include "coproc/supervisor.h" diff --git a/src/v/coproc/service.cc b/src/v/coproc/service.cc index e7c0d9939aa63..6ca9e24608b9d 100644 --- a/src/v/coproc/service.cc +++ b/src/v/coproc/service.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "service.h" #include "cluster/namespace.h" diff --git a/src/v/coproc/service.h b/src/v/coproc/service.h index d83b096a75ef1..b5b4726c1da5d 100644 --- a/src/v/coproc/service.h +++ b/src/v/coproc/service.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "cluster/namespace.h" #include "coproc/router.h" diff --git a/src/v/coproc/tests/coproc_fixture_base.cc b/src/v/coproc/tests/coproc_fixture_base.cc index 21eac944810ca..09e4d89c2bce2 100644 --- a/src/v/coproc/tests/coproc_fixture_base.cc +++ b/src/v/coproc/tests/coproc_fixture_base.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc_fixture_base.h" #include "coproc/errc.h" diff --git a/src/v/coproc/tests/coproc_fixture_base.h b/src/v/coproc/tests/coproc_fixture_base.h index e2c8332ff5013..793a29eda2700 100644 --- a/src/v/coproc/tests/coproc_fixture_base.h +++ b/src/v/coproc/tests/coproc_fixture_base.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/router.h" #include "coproc/types.h" diff --git a/src/v/coproc/tests/coproc_test_fixture.h b/src/v/coproc/tests/coproc_test_fixture.h index b21c8ee63a4e8..c4147ed810aa6 100644 --- a/src/v/coproc/tests/coproc_test_fixture.h +++ b/src/v/coproc/tests/coproc_test_fixture.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/logger.h" #include "coproc/tests/coproc_fixture_base.h" diff --git a/src/v/coproc/tests/coprocessor.h b/src/v/coproc/tests/coprocessor.h index 0217a788e3ddc..5d2fa74dd564c 100644 --- a/src/v/coproc/tests/coprocessor.h +++ b/src/v/coproc/tests/coprocessor.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/types.h" #include "model/fundamental.h" diff --git a/src/v/coproc/tests/materialized_type_test.cc b/src/v/coproc/tests/materialized_type_test.cc index 8c2a54e99e841..7a4c65c648c6e 100644 --- a/src/v/coproc/tests/materialized_type_test.cc +++ b/src/v/coproc/tests/materialized_type_test.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/types.h" #include "model/fundamental.h" diff --git a/src/v/coproc/tests/router_test.cc b/src/v/coproc/tests/router_test.cc index 4fb8b589d6354..919472a18a3f3 100644 --- a/src/v/coproc/tests/router_test.cc +++ b/src/v/coproc/tests/router_test.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/tests/coproc_fixture_base.h" #include "coproc/tests/coproc_test_fixture.h" #include "coproc/tests/coprocessor.h" diff --git a/src/v/coproc/tests/script_manager_service_test.cc b/src/v/coproc/tests/script_manager_service_test.cc index c05091ac4f827..bc2ce31a2b25d 100644 --- a/src/v/coproc/tests/script_manager_service_test.cc +++ b/src/v/coproc/tests/script_manager_service_test.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/router.h" #include "coproc/script_manager.h" #include "coproc/service.h" diff --git a/src/v/coproc/tests/supervisor.cc b/src/v/coproc/tests/supervisor.cc index 1ad58a21e701a..c523b7af476c9 100644 --- a/src/v/coproc/tests/supervisor.cc +++ b/src/v/coproc/tests/supervisor.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/tests/supervisor.h" #include "coproc/logger.h" diff --git a/src/v/coproc/tests/supervisor.h b/src/v/coproc/tests/supervisor.h index 7e9f13ea6113a..d37e9d159fb6b 100644 --- a/src/v/coproc/tests/supervisor.h +++ b/src/v/coproc/tests/supervisor.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/supervisor.h" #include "coproc/tests/coprocessor.h" diff --git a/src/v/coproc/tests/two_way_split_copro.h b/src/v/coproc/tests/two_way_split_copro.h index db47a1b7a0070..0c6c031a17491 100644 --- a/src/v/coproc/tests/two_way_split_copro.h +++ b/src/v/coproc/tests/two_way_split_copro.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/tests/coprocessor.h" #include "storage/record_batch_builder.h" diff --git a/src/v/coproc/tests/utils.cc b/src/v/coproc/tests/utils.cc index eb20fa8f2be1a..cc86c027949fd 100644 --- a/src/v/coproc/tests/utils.cc +++ b/src/v/coproc/tests/utils.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "coproc/tests/utils.h" #include "model/record_batch_reader.h" diff --git a/src/v/coproc/tests/utils.h b/src/v/coproc/tests/utils.h index 6a02564bf713d..8faa1bce87056 100644 --- a/src/v/coproc/tests/utils.h +++ b/src/v/coproc/tests/utils.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "coproc/types.h" #include "model/fundamental.h" diff --git a/src/v/coproc/types.cc b/src/v/coproc/types.cc index 1dd998b733b25..886d336e9c124 100644 --- a/src/v/coproc/types.cc +++ b/src/v/coproc/types.cc @@ -1,3 +1,11 @@ +// Copyright 2020 Vectorized, Inc. +// +// Licensed as a Redpanda Enterprise file under the Redpanda Community +// License (the "License"); you may not use this file except in compliance with +// the License. You may obtain a copy of the License at +// +// https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + #include "types.h" #include "model/async_adl_serde.h" diff --git a/src/v/coproc/types.h b/src/v/coproc/types.h index 4ac8a0445bcbc..70b19624c9409 100644 --- a/src/v/coproc/types.h +++ b/src/v/coproc/types.h @@ -1,3 +1,13 @@ +/* + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + #pragma once #include "model/adl_serde.h" diff --git a/tools/ts-generator/example/demo.ts b/tools/ts-generator/example/demo.ts index 7c342d5510ab9..d8058a8392c75 100644 --- a/tools/ts-generator/example/demo.ts +++ b/tools/ts-generator/example/demo.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { Class1, Class2, Class3 } from "./generated"; import * as assert from "assert"; diff --git a/tools/ts-generator/example/functions.ts b/tools/ts-generator/example/functions.ts index ecd2c4b2b6f02..0ec939b2c057d 100644 --- a/tools/ts-generator/example/functions.ts +++ b/tools/ts-generator/example/functions.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + // receive int64 and return Uint64 const encodeZigzag = (field: bigint): bigint => { // Create Bigint with 64 bytes length and sign 63 diff --git a/tools/ts-generator/example/generated.ts b/tools/ts-generator/example/generated.ts index 9bf3da9a7c43e..ea0d824b4d0e2 100644 --- a/tools/ts-generator/example/generated.ts +++ b/tools/ts-generator/example/generated.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + // Code generated // import Buffer Functions import BF from "./functions"; diff --git a/tools/ts-generator/rpc/example/demo.ts b/tools/ts-generator/rpc/example/demo.ts index 91fd2cca34c27..4d20abeb36b93 100644 --- a/tools/ts-generator/rpc/example/demo.ts +++ b/tools/ts-generator/rpc/example/demo.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { RegistrationClient, RegistrationServer } from "./generatedServer"; import { DisableTopicsReply, diff --git a/tools/ts-generator/rpc/example/functions.ts b/tools/ts-generator/rpc/example/functions.ts index 5a0700b7ed2e1..fb772ba6bff6a 100644 --- a/tools/ts-generator/rpc/example/functions.ts +++ b/tools/ts-generator/rpc/example/functions.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { IOBuf } from "../../../../src/js/modules/utilities/IOBuf"; // receive int64 and return Uint64 diff --git a/tools/ts-generator/rpc/example/generatedServer.ts b/tools/ts-generator/rpc/example/generatedServer.ts index 2841ded4ad9ee..a84e257e3beaa 100644 --- a/tools/ts-generator/rpc/example/generatedServer.ts +++ b/tools/ts-generator/rpc/example/generatedServer.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { createConnection, Socket, diff --git a/tools/ts-generator/rpc/example/generatedType.ts b/tools/ts-generator/rpc/example/generatedType.ts index de21d73cd587e..6b20de58062f5 100644 --- a/tools/ts-generator/rpc/example/generatedType.ts +++ b/tools/ts-generator/rpc/example/generatedType.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + // Code generated by v/tools/ts-generator/rpcgen_js.py // import Buffer Functions import BF from "./functions"; diff --git a/tools/ts-generator/rpc/rpc_gen_js.py b/tools/ts-generator/rpc/rpc_gen_js.py index 0703c6e6d5f3d..1a83c5815adb0 100644 --- a/tools/ts-generator/rpc/rpc_gen_js.py +++ b/tools/ts-generator/rpc/rpc_gen_js.py @@ -1,4 +1,12 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Licensed as a Redpanda Enterprise file under the Redpanda Community +# License (the "License"); you may not use this file except in compliance with +# the License. You may obtain a copy of the License at +# +# https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + import sys import os import logging diff --git a/tools/ts-generator/types/functions.ts b/tools/ts-generator/types/functions.ts index 92b9c531aebca..8d9d6b68b65cc 100644 --- a/tools/ts-generator/types/functions.ts +++ b/tools/ts-generator/types/functions.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import { IOBuf } from "../../utilities/IOBuf"; // receive int64 and return Uint64 diff --git a/tools/ts-generator/types/test.ts b/tools/ts-generator/types/test.ts index 864eabd1cc30d..3a6c906f2b578 100644 --- a/tools/ts-generator/types/test.ts +++ b/tools/ts-generator/types/test.ts @@ -1,3 +1,13 @@ +/** + * Copyright 2020 Vectorized, Inc. + * + * Licensed as a Redpanda Enterprise file under the Redpanda Community + * License (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + */ + import BF from "./functions"; import * as asserts from "assert"; diff --git a/tools/ts-generator/types/types_gen_js.py b/tools/ts-generator/types/types_gen_js.py index f8160a93b9171..7a73e1d40fb38 100644 --- a/tools/ts-generator/types/types_gen_js.py +++ b/tools/ts-generator/types/types_gen_js.py @@ -1,4 +1,12 @@ #!/usr/bin/env python3 +# Copyright 2020 Vectorized, Inc. +# +# Licensed as a Redpanda Enterprise file under the Redpanda Community +# License (the "License"); you may not use this file except in compliance with +# the License. You may obtain a copy of the License at +# +# https://github.com/vectorizedio/redpanda/blob/master/licenses/rcl.md + import sys import os import logging