From aee282f647c8ea0cb31925c6dec398b40c66f9ba Mon Sep 17 00:00:00 2001 From: Andrew Hsu Date: Mon, 21 Mar 2022 20:47:39 +0000 Subject: [PATCH 1/5] replace vectorized with redpanda in 2020 copyright find . -type f -exec sed -i 's|Copyright 2020 Vectorized, Inc.|Copyright 2020 Redpanda Data, Inc.|g' {} \; --- .dir-locals.el | 2 +- .github/workflows/homebrew-publish.yml | 2 +- .github/workflows/lint.yml | 2 +- .github/workflows/redpanda-build.yml | 2 +- .github/workflows/rpk-build.yml | 2 +- .github/workflows/wasm-publish.yml | 2 +- build.sh | 2 +- conf/redpanda.yaml | 2 +- install-dependencies.sh | 2 +- licenses/bsl_header.txt | 2 +- licenses/rcl_header.txt | 2 +- src/consistency-testing/iofaults/iofaults.py | 2 +- src/go/k8s/helm-chart/charts/ci/ct.yaml | 2 +- .../k8s/helm-chart/charts/redpanda-operator/templates/NOTES.txt | 2 +- .../helm-chart/charts/redpanda-operator/templates/_helpers.tpl | 2 +- .../charts/redpanda-operator/templates/certificate.yaml | 2 +- .../charts/redpanda-operator/templates/clusterrole.yaml | 2 +- .../charts/redpanda-operator/templates/clusterrole_binding.yaml | 2 +- .../charts/redpanda-operator/templates/clusterrole_metrics.yaml | 2 +- .../charts/redpanda-operator/templates/clusterrole_proxy.yaml | 2 +- .../redpanda-operator/templates/clusterrole_proxy_binding.yaml | 2 +- .../charts/redpanda-operator/templates/configmap.yaml | 2 +- .../charts/redpanda-operator/templates/deployment.yaml | 2 +- .../helm-chart/charts/redpanda-operator/templates/issuer.yaml | 2 +- .../charts/redpanda-operator/templates/mutating_webhook.yaml | 2 +- .../k8s/helm-chart/charts/redpanda-operator/templates/role.yaml | 2 +- .../charts/redpanda-operator/templates/role_binding.yaml | 2 +- .../charts/redpanda-operator/templates/service_account.yaml | 2 +- .../charts/redpanda-operator/templates/service_metrics.yaml | 2 +- .../charts/redpanda-operator/templates/service_webhook.yaml | 2 +- .../charts/redpanda-operator/templates/servicemonitor.yaml | 2 +- .../charts/redpanda-operator/templates/validating_webhook.yaml | 2 +- src/go/rpk/build.sh | 2 +- src/go/rpk/cmd/rpk/main.go | 2 +- src/go/rpk/pkg/api/api.go | 2 +- src/go/rpk/pkg/api/api_test.go | 2 +- src/go/rpk/pkg/cli/cmd/container.go | 2 +- src/go/rpk/pkg/cli/cmd/container/common/client.go | 2 +- src/go/rpk/pkg/cli/cmd/container/common/common.go | 2 +- src/go/rpk/pkg/cli/cmd/container/common/test.go | 2 +- src/go/rpk/pkg/cli/cmd/container/purge.go | 2 +- src/go/rpk/pkg/cli/cmd/container/purge_test.go | 2 +- src/go/rpk/pkg/cli/cmd/container/start.go | 2 +- src/go/rpk/pkg/cli/cmd/container/start_test.go | 2 +- src/go/rpk/pkg/cli/cmd/container/stop.go | 2 +- src/go/rpk/pkg/cli/cmd/container/stop_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/autocomplete.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/dashboard_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/graph.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/graph_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/row.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/row_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/singlestat_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/graf/text.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/grafana.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/grafana_test.go | 2 +- src/go/rpk/pkg/cli/cmd/generate/prometheus.go | 2 +- src/go/rpk/pkg/cli/cmd/iotune.go | 2 +- src/go/rpk/pkg/cli/cmd/iotune_test.go | 2 +- src/go/rpk/pkg/cli/cmd/root.go | 2 +- src/go/rpk/pkg/cli/cmd/root_darwin.go | 2 +- src/go/rpk/pkg/cli/cmd/root_linux.go | 2 +- src/go/rpk/pkg/cli/cmd/status.go | 2 +- src/go/rpk/pkg/cli/cmd/version.go | 2 +- src/go/rpk/pkg/cli/cmd/version/version.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/generate.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/generate_test.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/template/package_json.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/template/wasm_test_case.go | 2 +- src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go | 2 +- src/go/rpk/pkg/cli/flags.go | 2 +- src/go/rpk/pkg/cli/log_formatter.go | 2 +- src/go/rpk/pkg/cli/ui/tables.go | 2 +- src/go/rpk/pkg/cloud/aws/aws.go | 2 +- src/go/rpk/pkg/cloud/gcp/gcp.go | 2 +- src/go/rpk/pkg/cloud/vendor/vendor.go | 2 +- src/go/rpk/pkg/cloud/vendors.go | 2 +- src/go/rpk/pkg/cloud/vendors_test.go | 2 +- src/go/rpk/pkg/config/config.go | 2 +- src/go/rpk/pkg/config/config_test.go | 2 +- src/go/rpk/pkg/config/find.go | 2 +- src/go/rpk/pkg/config/find_test.go | 2 +- src/go/rpk/pkg/config/license.go | 2 +- src/go/rpk/pkg/config/license_test.go | 2 +- src/go/rpk/pkg/config/manager.go | 2 +- src/go/rpk/pkg/config/params.go | 2 +- src/go/rpk/pkg/config/schema.go | 2 +- src/go/rpk/pkg/kafka/client_franz.go | 2 +- src/go/rpk/pkg/net/interfaces.go | 2 +- src/go/rpk/pkg/os/commands.go | 2 +- src/go/rpk/pkg/os/lock.go | 2 +- src/go/rpk/pkg/os/proc.go | 2 +- src/go/rpk/pkg/os/proc_test.go | 2 +- src/go/rpk/pkg/out/out.go | 2 +- src/go/rpk/pkg/redpanda/launcher.go | 2 +- src/go/rpk/pkg/redpanda/launcher_test.go | 2 +- src/go/rpk/pkg/redpanda/paths.go | 2 +- src/go/rpk/pkg/system/cgroup.go | 2 +- src/go/rpk/pkg/system/cgroup_test.go | 2 +- src/go/rpk/pkg/system/cpu.go | 2 +- src/go/rpk/pkg/system/filesystem/fs.go | 2 +- src/go/rpk/pkg/system/filesystem/fs_darwin.go | 2 +- src/go/rpk/pkg/system/filesystem/fs_linux.go | 2 +- src/go/rpk/pkg/system/filesystem/fs_test.go | 2 +- src/go/rpk/pkg/system/filesystem/types.go | 2 +- src/go/rpk/pkg/system/grub.go | 2 +- src/go/rpk/pkg/system/grub_test.go | 2 +- src/go/rpk/pkg/system/memory.go | 2 +- src/go/rpk/pkg/system/memory_darwin.go | 2 +- src/go/rpk/pkg/system/memory_linux.go | 2 +- src/go/rpk/pkg/system/ntp.go | 2 +- src/go/rpk/pkg/system/ntp_test.go | 2 +- src/go/rpk/pkg/system/runtime_options.go | 2 +- src/go/rpk/pkg/system/runtime_options_test.go | 2 +- src/go/rpk/pkg/system/systemd/client.go | 2 +- src/go/rpk/pkg/system/systemd/dbus.go | 2 +- src/go/rpk/pkg/system/systemd/mock.go | 2 +- src/go/rpk/pkg/system/utils.go | 2 +- src/go/rpk/pkg/system/utils_darwin.go | 2 +- src/go/rpk/pkg/system/utils_linux.go | 2 +- src/go/rpk/pkg/tuners/aggregated_tunable.go | 2 +- src/go/rpk/pkg/tuners/aggregated_tunable_test.go | 2 +- src/go/rpk/pkg/tuners/aio.go | 2 +- src/go/rpk/pkg/tuners/aio_test.go | 2 +- src/go/rpk/pkg/tuners/check.go | 2 +- src/go/rpk/pkg/tuners/checked_tunable.go | 2 +- src/go/rpk/pkg/tuners/checked_tunable_test.go | 2 +- src/go/rpk/pkg/tuners/checker.go | 2 +- src/go/rpk/pkg/tuners/clocksource.go | 2 +- src/go/rpk/pkg/tuners/coredump/tuner.go | 2 +- src/go/rpk/pkg/tuners/coredump/tuner_test.go | 2 +- src/go/rpk/pkg/tuners/cpu/tuner.go | 2 +- src/go/rpk/pkg/tuners/disk/block_device.go | 2 +- src/go/rpk/pkg/tuners/disk/block_device_darwin.go | 2 +- src/go/rpk/pkg/tuners/disk/block_device_linux.go | 2 +- src/go/rpk/pkg/tuners/disk/block_device_test.go | 2 +- src/go/rpk/pkg/tuners/disk/block_devices.go | 2 +- src/go/rpk/pkg/tuners/disk/block_devices_darwin.go | 2 +- src/go/rpk/pkg/tuners/disk/block_devices_linux.go | 2 +- src/go/rpk/pkg/tuners/disk/block_devices_test.go | 2 +- src/go/rpk/pkg/tuners/disk/device_features.go | 2 +- src/go/rpk/pkg/tuners/disk/device_features_test.go | 2 +- src/go/rpk/pkg/tuners/disk_checkers.go | 2 +- src/go/rpk/pkg/tuners/disk_nomerges_tuner.go | 2 +- src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go | 2 +- src/go/rpk/pkg/tuners/disk_scheduler_tuner.go | 2 +- src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go | 2 +- src/go/rpk/pkg/tuners/disk_tuner.go | 2 +- src/go/rpk/pkg/tuners/disks_irq_tuner.go | 2 +- src/go/rpk/pkg/tuners/disks_irq_tuner_test.go | 2 +- src/go/rpk/pkg/tuners/equality_checker.go | 2 +- src/go/rpk/pkg/tuners/equality_checker_test.go | 2 +- src/go/rpk/pkg/tuners/ethtool/ethtool.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/backup_file.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/command.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/execute.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go | 2 +- .../rpk/pkg/tuners/executors/commands/systemd_install_unit.go | 2 +- .../pkg/tuners/executors/commands/systemd_install_unit_test.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/systemd_start_unit.go | 2 +- .../pkg/tuners/executors/commands/systemd_start_unit_test.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/write_file.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/write_file_lines.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/write_file_test.go | 2 +- src/go/rpk/pkg/tuners/executors/direct.go | 2 +- src/go/rpk/pkg/tuners/executors/executor.go | 2 +- src/go/rpk/pkg/tuners/executors/script_rendering.go | 2 +- src/go/rpk/pkg/tuners/factory/factory_test.go | 2 +- src/go/rpk/pkg/tuners/file_existance_checker.go | 2 +- src/go/rpk/pkg/tuners/float_checker.go | 2 +- src/go/rpk/pkg/tuners/float_checker_test.go | 2 +- src/go/rpk/pkg/tuners/fstrim.go | 2 +- src/go/rpk/pkg/tuners/fstrim_test.go | 2 +- src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner.go | 2 +- src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner_test.go | 2 +- src/go/rpk/pkg/tuners/hwloc/cpuset.go | 2 +- src/go/rpk/pkg/tuners/hwloc/cpuset_test.go | 2 +- src/go/rpk/pkg/tuners/hwloc/hwloc.go | 2 +- src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go | 2 +- src/go/rpk/pkg/tuners/int_checker.go | 2 +- src/go/rpk/pkg/tuners/int_checker_test.go | 2 +- src/go/rpk/pkg/tuners/iotune.go | 2 +- src/go/rpk/pkg/tuners/iotune/data.go | 2 +- src/go/rpk/pkg/tuners/iotune/data_test.go | 2 +- src/go/rpk/pkg/tuners/iotune/io_tune.go | 2 +- src/go/rpk/pkg/tuners/irq/balance_service.go | 2 +- src/go/rpk/pkg/tuners/irq/balance_service_test.go | 2 +- src/go/rpk/pkg/tuners/irq/cpu_masks.go | 2 +- src/go/rpk/pkg/tuners/irq/cpu_masks_test.go | 2 +- src/go/rpk/pkg/tuners/irq/device_info.go | 2 +- src/go/rpk/pkg/tuners/irq/device_info_test.go | 2 +- src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go | 2 +- src/go/rpk/pkg/tuners/irq/proc_file.go | 2 +- src/go/rpk/pkg/tuners/irq/proc_file_test.go | 2 +- src/go/rpk/pkg/tuners/irq/utils.go | 2 +- src/go/rpk/pkg/tuners/kernel_version.go | 2 +- src/go/rpk/pkg/tuners/kernel_version_darwin.go | 2 +- src/go/rpk/pkg/tuners/kernel_version_linux.go | 2 +- src/go/rpk/pkg/tuners/kernel_version_test.go | 2 +- src/go/rpk/pkg/tuners/net_checkers.go | 2 +- src/go/rpk/pkg/tuners/net_tuners.go | 2 +- src/go/rpk/pkg/tuners/net_tuners_test.go | 2 +- src/go/rpk/pkg/tuners/network/const.go | 2 +- src/go/rpk/pkg/tuners/network/nic.go | 2 +- src/go/rpk/pkg/tuners/network/nic_test.go | 2 +- src/go/rpk/pkg/tuners/network/nics.go | 2 +- src/go/rpk/pkg/tuners/redpanda_checkers.go | 2 +- src/go/rpk/pkg/tuners/redpanda_checkers_test.go | 2 +- src/go/rpk/pkg/tuners/swappiness.go | 2 +- src/go/rpk/pkg/tuners/swappiness_test.go | 2 +- src/go/rpk/pkg/tuners/thp.go | 2 +- src/go/rpk/pkg/tuners/thp_test.go | 2 +- src/go/rpk/pkg/tuners/tunable.go | 2 +- src/go/rpk/pkg/tuners/tune_result.go | 2 +- src/go/rpk/pkg/tuners/tune_result_test.go | 2 +- src/go/rpk/pkg/utils/chained_error.go | 2 +- src/go/rpk/pkg/utils/collect.go | 2 +- src/go/rpk/pkg/utils/files.go | 2 +- src/go/rpk/pkg/utils/files_test.go | 2 +- src/go/rpk/pkg/utils/os.go | 2 +- src/go/rpk/pkg/utils/strings.go | 2 +- src/go/rpk/pkg/utils/strings_test.go | 2 +- src/go/rpk/pkg/yaml/yaml.go | 2 +- src/js/build.sh | 2 +- src/js/generate-entries.sh | 2 +- src/js/modules/domain/Handle.ts | 2 +- src/js/modules/hashing/crc32.ts | 2 +- src/js/modules/hashing/xxhash.ts | 2 +- src/js/modules/public/Coprocessor.ts | 2 +- src/js/modules/public/SimpleTransform.ts | 2 +- src/js/modules/public/Utils.ts | 2 +- src/js/modules/public/index.ts | 2 +- src/js/modules/rpc/errors.ts | 2 +- src/js/modules/rpc/parser.ts | 2 +- src/js/modules/rpc/server.ts | 2 +- src/js/modules/rpc/service.ts | 2 +- src/js/modules/rpc/types.ts | 2 +- src/js/modules/supervisors/HandleTable.ts | 2 +- src/js/modules/supervisors/Repository.ts | 2 +- src/js/modules/utilities/Checksum.ts | 2 +- src/js/modules/utilities/IOBuf.ts | 2 +- src/js/modules/utilities/Logging.ts | 2 +- src/js/modules/utilities/Map.ts | 2 +- src/js/publish-wasm-dependecy.js | 2 +- src/js/test/rpc/server.test.ts | 2 +- src/js/test/supervisors/Repository.test.ts | 2 +- src/js/test/testUtilities.ts | 2 +- src/js/test/utilities/Checksum.test.ts | 2 +- src/js/test/utilities/CoprocessorTest.ts | 2 +- src/js/test/utilities/iobuf.test.ts | 2 +- src/v/bytes/bytes.cc | 2 +- src/v/bytes/bytes.h | 2 +- src/v/bytes/details/io_allocation_size.h | 2 +- src/v/bytes/details/io_byte_iterator.h | 2 +- src/v/bytes/details/io_fragment.h | 2 +- src/v/bytes/details/io_iterator_consumer.h | 2 +- src/v/bytes/details/io_placeholder.h | 2 +- src/v/bytes/details/out_of_range.h | 2 +- src/v/bytes/iobuf.cc | 2 +- src/v/bytes/iobuf.h | 2 +- src/v/bytes/iobuf_istreambuf.h | 2 +- src/v/bytes/iobuf_ostreambuf.h | 2 +- src/v/bytes/iobuf_parser.h | 2 +- src/v/bytes/tests/bytes_tests.cc | 2 +- src/v/bytes/tests/iobuf_tests.cc | 2 +- src/v/bytes/tests/iobuf_utils_tests.cc | 2 +- src/v/bytes/tests/utils.h | 2 +- src/v/bytes/utils.h | 2 +- src/v/cluster/cluster_utils.cc | 2 +- src/v/cluster/cluster_utils.h | 2 +- src/v/cluster/commands.h | 2 +- src/v/cluster/controller.cc | 2 +- src/v/cluster/controller.h | 2 +- src/v/cluster/controller_api.cc | 2 +- src/v/cluster/controller_api.h | 2 +- src/v/cluster/controller_backend.cc | 2 +- src/v/cluster/controller_backend.h | 2 +- src/v/cluster/controller_stm.h | 2 +- src/v/cluster/errc.h | 2 +- src/v/cluster/fwd.h | 2 +- src/v/cluster/health_monitor_backend.cc | 2 +- src/v/cluster/health_monitor_backend.h | 2 +- src/v/cluster/health_monitor_frontend.cc | 2 +- src/v/cluster/health_monitor_frontend.h | 2 +- src/v/cluster/health_monitor_types.cc | 2 +- src/v/cluster/health_monitor_types.h | 2 +- src/v/cluster/id_allocator.cc | 2 +- src/v/cluster/id_allocator.h | 2 +- src/v/cluster/id_allocator_frontend.cc | 2 +- src/v/cluster/id_allocator_frontend.h | 2 +- src/v/cluster/id_allocator_stm.cc | 2 +- src/v/cluster/id_allocator_stm.h | 2 +- src/v/cluster/logger.cc | 2 +- src/v/cluster/logger.h | 2 +- src/v/cluster/members_frontend.cc | 2 +- src/v/cluster/members_frontend.h | 2 +- src/v/cluster/members_manager.cc | 2 +- src/v/cluster/members_manager.h | 2 +- src/v/cluster/members_table.cc | 2 +- src/v/cluster/members_table.h | 2 +- src/v/cluster/metadata_cache.cc | 2 +- src/v/cluster/metadata_cache.h | 2 +- src/v/cluster/metadata_dissemination_handler.cc | 2 +- src/v/cluster/metadata_dissemination_handler.h | 2 +- src/v/cluster/metadata_dissemination_service.cc | 2 +- src/v/cluster/metadata_dissemination_service.h | 2 +- src/v/cluster/metadata_dissemination_types.h | 2 +- src/v/cluster/metadata_dissemination_utils.cc | 2 +- src/v/cluster/metadata_dissemination_utils.h | 2 +- src/v/cluster/metrics_reporter.h | 2 +- src/v/cluster/notification_latch.cc | 2 +- src/v/cluster/notification_latch.h | 2 +- src/v/cluster/ntp_callbacks.h | 2 +- src/v/cluster/partition.cc | 2 +- src/v/cluster/partition.h | 2 +- src/v/cluster/partition_leaders_table.cc | 2 +- src/v/cluster/partition_leaders_table.h | 2 +- src/v/cluster/partition_manager.cc | 2 +- src/v/cluster/partition_manager.h | 2 +- src/v/cluster/partition_probe.cc | 2 +- src/v/cluster/partition_probe.h | 2 +- src/v/cluster/persisted_stm.cc | 2 +- src/v/cluster/persisted_stm.h | 2 +- src/v/cluster/raft0_utils.h | 2 +- src/v/cluster/rm_group_proxy.h | 2 +- src/v/cluster/rm_partition_frontend.cc | 2 +- src/v/cluster/rm_partition_frontend.h | 2 +- src/v/cluster/rm_stm.cc | 2 +- src/v/cluster/rm_stm.h | 2 +- src/v/cluster/scheduling/allocation_node.cc | 2 +- src/v/cluster/scheduling/allocation_node.h | 2 +- src/v/cluster/scheduling/allocation_state.cc | 2 +- src/v/cluster/scheduling/allocation_state.h | 2 +- src/v/cluster/scheduling/allocation_strategy.cc | 2 +- src/v/cluster/scheduling/allocation_strategy.h | 2 +- src/v/cluster/scheduling/constraints.cc | 2 +- src/v/cluster/scheduling/constraints.h | 2 +- src/v/cluster/scheduling/leader_balancer.cc | 2 +- src/v/cluster/scheduling/leader_balancer.h | 2 +- src/v/cluster/scheduling/leader_balancer_probe.cc | 2 +- src/v/cluster/scheduling/leader_balancer_probe.h | 2 +- src/v/cluster/scheduling/leader_balancer_strategy.h | 2 +- src/v/cluster/scheduling/partition_allocator.cc | 2 +- src/v/cluster/scheduling/partition_allocator.h | 2 +- src/v/cluster/scheduling/types.cc | 2 +- src/v/cluster/scheduling/types.h | 2 +- src/v/cluster/security_frontend.cc | 2 +- src/v/cluster/security_frontend.h | 2 +- src/v/cluster/security_manager.cc | 2 +- src/v/cluster/service.cc | 2 +- src/v/cluster/service.h | 2 +- src/v/cluster/shard_table.h | 2 +- src/v/cluster/simple_batch_builder.h | 2 +- src/v/cluster/tests/allocation_bench.cc | 2 +- src/v/cluster/tests/autocreate_test.cc | 2 +- src/v/cluster/tests/cluster_test_fixture.h | 2 +- src/v/cluster/tests/cluster_tests.cc | 2 +- src/v/cluster/tests/cluster_utils_tests.cc | 2 +- src/v/cluster/tests/commands_serialization_test.cc | 2 +- src/v/cluster/tests/configuration_change_test.cc | 2 +- src/v/cluster/tests/controller_api_tests.cc | 2 +- src/v/cluster/tests/controller_state_test.cc | 2 +- src/v/cluster/tests/health_monitor_test.cc | 2 +- src/v/cluster/tests/id_allocator_stm_test.cc | 2 +- src/v/cluster/tests/idempotency_tests.cc | 2 +- src/v/cluster/tests/metadata_dissemination_test.cc | 2 +- src/v/cluster/tests/metadata_dissemination_utils_test.cc | 2 +- src/v/cluster/tests/notification_latch_test.cc | 2 +- src/v/cluster/tests/partition_allocator_fixture.h | 2 +- src/v/cluster/tests/partition_allocator_tests.cc | 2 +- src/v/cluster/tests/rebalancing_tests_fixture.h | 2 +- src/v/cluster/tests/rm_stm_tests.cc | 2 +- src/v/cluster/tests/serialization_rt_test.cc | 2 +- src/v/cluster/tests/simple_batch_builder_test.cc | 2 +- src/v/cluster/tests/tm_stm_tests.cc | 2 +- src/v/cluster/tests/topic_table_fixture.h | 2 +- src/v/cluster/tests/topic_table_test.cc | 2 +- src/v/cluster/tests/topic_updates_dispatcher_test.cc | 2 +- src/v/cluster/tests/utils.h | 2 +- src/v/cluster/tm_stm.cc | 2 +- src/v/cluster/tm_stm.h | 2 +- src/v/cluster/topic_table.cc | 2 +- src/v/cluster/topic_table.h | 2 +- src/v/cluster/topic_updates_dispatcher.cc | 2 +- src/v/cluster/topic_updates_dispatcher.h | 2 +- src/v/cluster/topics_frontend.cc | 2 +- src/v/cluster/topics_frontend.h | 2 +- src/v/cluster/tx_gateway.cc | 2 +- src/v/cluster/tx_gateway.h | 2 +- src/v/cluster/tx_gateway_frontend.cc | 2 +- src/v/cluster/tx_gateway_frontend.h | 2 +- src/v/cluster/tx_utils.h | 2 +- src/v/cluster/types.cc | 2 +- src/v/cluster/types.h | 2 +- src/v/compression/compression.cc | 2 +- src/v/compression/compression.h | 2 +- src/v/compression/internal/gzip_compressor.cc | 2 +- src/v/compression/internal/gzip_compressor.h | 2 +- src/v/compression/internal/lz4_frame_compressor.cc | 2 +- src/v/compression/internal/lz4_frame_compressor.h | 2 +- src/v/compression/internal/snappy_java_compressor.cc | 2 +- src/v/compression/internal/snappy_java_compressor.h | 2 +- src/v/compression/internal/zstd_compressor.h | 2 +- src/v/compression/logger.cc | 2 +- src/v/compression/logger.h | 2 +- src/v/compression/snappy_standard_compressor.cc | 2 +- src/v/compression/snappy_standard_compressor.h | 2 +- src/v/compression/stream_zstd.cc | 2 +- src/v/compression/stream_zstd.h | 2 +- src/v/compression/tests/zstd_stream_bench.cc | 2 +- src/v/compression/tests/zstd_tests.cc | 2 +- src/v/config/base_property.cc | 2 +- src/v/config/base_property.h | 2 +- src/v/config/config_store.h | 2 +- src/v/config/configuration.cc | 2 +- src/v/config/configuration.h | 2 +- src/v/config/data_directory_path.h | 2 +- src/v/config/endpoint_tls_config.h | 2 +- src/v/config/property.h | 2 +- src/v/config/rjson_serialization.cc | 2 +- src/v/config/rjson_serialization.h | 2 +- src/v/config/seed_server.h | 2 +- src/v/config/tests/advertised_kafka_api_test.cc | 2 +- src/v/config/tests/config_store_test.cc | 2 +- src/v/config/tests/custom_aggregate.h | 2 +- src/v/config/tests/seed_server_property_test.cc | 2 +- src/v/config/tests/socket_address_convert_test.cc | 2 +- src/v/config/tests/tls_config_convert_test.cc | 2 +- src/v/config/tls_config.h | 2 +- src/v/config/validation_error.h | 2 +- src/v/coproc/api.h | 2 +- src/v/coproc/errc.h | 2 +- src/v/coproc/event_listener.cc | 2 +- src/v/coproc/event_listener.h | 2 +- src/v/coproc/logger.cc | 2 +- src/v/coproc/logger.h | 2 +- src/v/coproc/offset_storage_utils.cc | 2 +- src/v/coproc/offset_storage_utils.h | 2 +- src/v/coproc/pacemaker.cc | 2 +- src/v/coproc/pacemaker.h | 2 +- src/v/coproc/script_context.cc | 2 +- src/v/coproc/script_context.h | 2 +- src/v/coproc/script_dispatcher.cc | 2 +- src/v/coproc/script_dispatcher.h | 2 +- src/v/coproc/service.h | 2 +- src/v/coproc/shared_script_resources.h | 2 +- src/v/coproc/tests/autocreate_topic_tests.cc | 2 +- src/v/coproc/tests/coproc_bench_tests.cc | 2 +- src/v/coproc/tests/event_listener_tests.cc | 2 +- src/v/coproc/tests/failure_recovery_tests.cc | 2 +- src/v/coproc/tests/fixtures/coproc_bench_fixture.cc | 2 +- src/v/coproc/tests/fixtures/coproc_bench_fixture.h | 2 +- src/v/coproc/tests/fixtures/coproc_test_fixture.cc | 2 +- src/v/coproc/tests/fixtures/coproc_test_fixture.h | 2 +- src/v/coproc/tests/fixtures/supervisor_test_fixture.h | 2 +- src/v/coproc/tests/kafka_api_materialized_tests.cc | 2 +- src/v/coproc/tests/offset_storage_utils_tests.cc | 2 +- src/v/coproc/tests/pacemaker_tests.cc | 2 +- src/v/coproc/tests/retry_logic_tests.cc | 2 +- src/v/coproc/tests/utils/coprocessor.h | 2 +- src/v/coproc/tests/utils/event_publisher_utils.cc | 2 +- src/v/coproc/tests/utils/event_publisher_utils.h | 2 +- src/v/coproc/tests/utils/supervisor.cc | 2 +- src/v/coproc/tests/utils/supervisor.h | 2 +- src/v/coproc/tests/utils/wasm_event_generator.cc | 2 +- src/v/coproc/tests/utils/wasm_event_generator.h | 2 +- src/v/coproc/tests/wasm_event_tests.cc | 2 +- src/v/coproc/types.cc | 2 +- src/v/coproc/types.h | 2 +- src/v/coproc/wasm_event.cc | 2 +- src/v/coproc/wasm_event.h | 2 +- src/v/finjector/hbadger.cc | 2 +- src/v/finjector/hbadger.h | 2 +- src/v/hashing/crc32c.h | 2 +- src/v/hashing/fnv.h | 2 +- src/v/hashing/jenkins.h | 2 +- src/v/hashing/jump_consistent_hash.h | 2 +- src/v/hashing/murmur.cc | 2 +- src/v/hashing/murmur.h | 2 +- src/v/hashing/secure.h | 2 +- src/v/hashing/tests/hash_bench.cc | 2 +- src/v/hashing/tests/secure_tests.cc | 2 +- src/v/hashing/tests/xx_tests.cc | 2 +- src/v/hashing/twang.h | 2 +- src/v/hashing/xx.h | 2 +- src/v/http/chunk_encoding.cc | 2 +- src/v/http/chunk_encoding.h | 2 +- src/v/http/client.cc | 2 +- src/v/http/client.h | 2 +- src/v/http/demo/client.cc | 2 +- src/v/http/demo/echo.py | 2 +- src/v/http/iobuf_body.cc | 2 +- src/v/http/iobuf_body.h | 2 +- src/v/http/logger.cc | 2 +- src/v/http/logger.h | 2 +- src/v/http/probe.h | 2 +- src/v/http/tests/framing_test.cc | 2 +- src/v/http/tests/http_client_test.cc | 2 +- src/v/json/json.cc | 2 +- src/v/json/json.h | 2 +- src/v/json/tests/json_serialization_test.cc | 2 +- src/v/kafka/client/assignment_plans.cc | 2 +- src/v/kafka/client/assignment_plans.h | 2 +- src/v/kafka/client/broker.cc | 2 +- src/v/kafka/client/broker.h | 2 +- src/v/kafka/client/brokers.cc | 2 +- src/v/kafka/client/brokers.h | 2 +- src/v/kafka/client/client.cc | 2 +- src/v/kafka/client/client.h | 2 +- src/v/kafka/client/configuration.cc | 2 +- src/v/kafka/client/configuration.h | 2 +- src/v/kafka/client/consumer.cc | 2 +- src/v/kafka/client/consumer.h | 2 +- src/v/kafka/client/exceptions.h | 2 +- src/v/kafka/client/fetch_session.cc | 2 +- src/v/kafka/client/fetcher.cc | 2 +- src/v/kafka/client/fetcher.h | 2 +- src/v/kafka/client/logger.h | 2 +- src/v/kafka/client/produce_batcher.h | 2 +- src/v/kafka/client/produce_partition.h | 2 +- src/v/kafka/client/producer.cc | 2 +- src/v/kafka/client/producer.h | 2 +- src/v/kafka/client/retry_with_mitigation.h | 2 +- src/v/kafka/client/test/consumer_group.cc | 2 +- src/v/kafka/client/test/fetch.cc | 2 +- src/v/kafka/client/test/fetch_session.cc | 2 +- src/v/kafka/client/test/fixture.h | 2 +- src/v/kafka/client/test/partitioners.cc | 2 +- src/v/kafka/client/test/produce.cc | 2 +- src/v/kafka/client/test/produce_batcher.cc | 2 +- src/v/kafka/client/test/produce_partition.cc | 2 +- src/v/kafka/client/test/reconnect.cc | 2 +- src/v/kafka/client/test/retry_with_mitigation.cc | 2 +- src/v/kafka/client/test/utils.h | 2 +- src/v/kafka/client/topic_cache.cc | 2 +- src/v/kafka/client/topic_cache.h | 2 +- src/v/kafka/client/transport.h | 2 +- src/v/kafka/protocol/add_offsets_to_txn.h | 2 +- src/v/kafka/protocol/add_partitions_to_txn.h | 2 +- src/v/kafka/protocol/alter_configs.h | 2 +- src/v/kafka/protocol/api_versions.h | 2 +- src/v/kafka/protocol/batch_consumer.h | 2 +- src/v/kafka/protocol/batch_reader.cc | 2 +- src/v/kafka/protocol/batch_reader.h | 2 +- src/v/kafka/protocol/create_acls.h | 2 +- src/v/kafka/protocol/create_partitions.h | 2 +- src/v/kafka/protocol/create_topics.h | 2 +- src/v/kafka/protocol/delete_acls.h | 2 +- src/v/kafka/protocol/delete_groups.h | 2 +- src/v/kafka/protocol/delete_topics.h | 2 +- src/v/kafka/protocol/describe_acls.h | 2 +- src/v/kafka/protocol/describe_configs.h | 2 +- src/v/kafka/protocol/describe_groups.h | 2 +- src/v/kafka/protocol/describe_log_dirs.h | 2 +- src/v/kafka/protocol/end_txn.h | 2 +- src/v/kafka/protocol/errors.cc | 2 +- src/v/kafka/protocol/errors.h | 2 +- src/v/kafka/protocol/exceptions.h | 2 +- src/v/kafka/protocol/fetch.h | 2 +- src/v/kafka/protocol/find_coordinator.h | 2 +- src/v/kafka/protocol/fwd.h | 2 +- src/v/kafka/protocol/heartbeat.h | 2 +- src/v/kafka/protocol/incremental_alter_configs.h | 2 +- src/v/kafka/protocol/init_producer_id.h | 2 +- src/v/kafka/protocol/join_group.h | 2 +- src/v/kafka/protocol/kafka_batch_adapter.cc | 2 +- src/v/kafka/protocol/kafka_batch_adapter.h | 2 +- src/v/kafka/protocol/leave_group.h | 2 +- src/v/kafka/protocol/list_groups.h | 2 +- src/v/kafka/protocol/list_offsets.h | 2 +- src/v/kafka/protocol/metadata.h | 2 +- src/v/kafka/protocol/offset_commit.h | 2 +- src/v/kafka/protocol/offset_fetch.h | 2 +- src/v/kafka/protocol/offset_for_leader_epoch.h | 2 +- src/v/kafka/protocol/produce.h | 2 +- src/v/kafka/protocol/request_reader.h | 2 +- src/v/kafka/protocol/response_writer.h | 2 +- src/v/kafka/protocol/sasl_authenticate.h | 2 +- src/v/kafka/protocol/sasl_handshake.h | 2 +- src/v/kafka/protocol/schemata/generator.py | 2 +- src/v/kafka/protocol/sync_group.h | 2 +- src/v/kafka/protocol/tests/batch_reader_test.cc | 2 +- src/v/kafka/protocol/tests/security_test.cc | 2 +- src/v/kafka/protocol/timeout.h | 2 +- src/v/kafka/protocol/txn_offset_commit.h | 2 +- src/v/kafka/protocol/types.h | 2 +- src/v/kafka/server/connection_context.cc | 2 +- src/v/kafka/server/connection_context.h | 2 +- src/v/kafka/server/coordinator_ntp_mapper.h | 2 +- src/v/kafka/server/fetch_metadata_cache.hh | 2 +- src/v/kafka/server/fetch_session.h | 2 +- src/v/kafka/server/fetch_session_cache.h | 2 +- src/v/kafka/server/fwd.h | 2 +- src/v/kafka/server/group.cc | 2 +- src/v/kafka/server/group.h | 2 +- src/v/kafka/server/group_manager.cc | 2 +- src/v/kafka/server/group_manager.h | 2 +- src/v/kafka/server/group_metadata.cc | 2 +- src/v/kafka/server/group_metadata.h | 2 +- src/v/kafka/server/group_metadata_migration.h | 2 +- src/v/kafka/server/group_recovery_consumer.cc | 2 +- src/v/kafka/server/group_recovery_consumer.h | 2 +- src/v/kafka/server/group_router.cc | 2 +- src/v/kafka/server/group_router.h | 2 +- src/v/kafka/server/handlers/add_offsets_to_txn.cc | 2 +- src/v/kafka/server/handlers/add_partitions_to_txn.cc | 2 +- src/v/kafka/server/handlers/alter_configs.cc | 2 +- src/v/kafka/server/handlers/api_versions.cc | 2 +- src/v/kafka/server/handlers/create_partitions.cc | 2 +- src/v/kafka/server/handlers/create_topics.cc | 2 +- src/v/kafka/server/handlers/delete_groups.cc | 2 +- src/v/kafka/server/handlers/delete_topics.cc | 2 +- src/v/kafka/server/handlers/describe_configs.cc | 2 +- src/v/kafka/server/handlers/describe_groups.cc | 2 +- src/v/kafka/server/handlers/end_txn.cc | 2 +- src/v/kafka/server/handlers/fetch.cc | 2 +- src/v/kafka/server/handlers/fetch/fetch_plan_executor.h | 2 +- src/v/kafka/server/handlers/fetch/fetch_planner.h | 2 +- src/v/kafka/server/handlers/find_coordinator.cc | 2 +- src/v/kafka/server/handlers/heartbeat.cc | 2 +- src/v/kafka/server/handlers/incremental_alter_configs.cc | 2 +- src/v/kafka/server/handlers/init_producer_id.cc | 2 +- src/v/kafka/server/handlers/join_group.cc | 2 +- src/v/kafka/server/handlers/leave_group.cc | 2 +- src/v/kafka/server/handlers/list_groups.cc | 2 +- src/v/kafka/server/handlers/list_offsets.cc | 2 +- src/v/kafka/server/handlers/metadata.cc | 2 +- src/v/kafka/server/handlers/offset_commit.cc | 2 +- src/v/kafka/server/handlers/offset_fetch.cc | 2 +- src/v/kafka/server/handlers/offset_for_leader_epoch.cc | 2 +- src/v/kafka/server/handlers/produce.cc | 2 +- src/v/kafka/server/handlers/sasl_authenticate.cc | 2 +- src/v/kafka/server/handlers/sasl_handshake.cc | 2 +- src/v/kafka/server/handlers/sync_group.cc | 2 +- src/v/kafka/server/handlers/topics/topic_utils.cc | 2 +- src/v/kafka/server/handlers/topics/topic_utils.h | 2 +- src/v/kafka/server/handlers/topics/types.cc | 2 +- src/v/kafka/server/handlers/topics/types.h | 2 +- src/v/kafka/server/handlers/topics/validators.h | 2 +- src/v/kafka/server/handlers/txn_offset_commit.cc | 2 +- src/v/kafka/server/logger.cc | 2 +- src/v/kafka/server/logger.h | 2 +- src/v/kafka/server/member.cc | 2 +- src/v/kafka/server/member.h | 2 +- src/v/kafka/server/protocol.cc | 2 +- src/v/kafka/server/protocol.h | 2 +- src/v/kafka/server/protocol_utils.cc | 2 +- src/v/kafka/server/protocol_utils.h | 2 +- src/v/kafka/server/quota_manager.cc | 2 +- src/v/kafka/server/quota_manager.h | 2 +- src/v/kafka/server/request_context.h | 2 +- src/v/kafka/server/requests.cc | 2 +- src/v/kafka/server/response.h | 2 +- src/v/kafka/server/rm_group_frontend.cc | 2 +- src/v/kafka/server/rm_group_frontend.h | 2 +- src/v/kafka/server/tests/alter_config_test.cc | 2 +- src/v/kafka/server/tests/api_versions_test.cc | 2 +- src/v/kafka/server/tests/create_topics_test.cc | 2 +- src/v/kafka/server/tests/delete_topics_test.cc | 2 +- src/v/kafka/server/tests/error_mapping_test.cc | 2 +- src/v/kafka/server/tests/fetch_session_test.cc | 2 +- src/v/kafka/server/tests/fetch_test.cc | 2 +- src/v/kafka/server/tests/find_coordinator_test.cc | 2 +- src/v/kafka/server/tests/group_metadata_serialization_test.cc | 2 +- src/v/kafka/server/tests/group_test.cc | 2 +- src/v/kafka/server/tests/list_offsets_test.cc | 2 +- src/v/kafka/server/tests/member_test.cc | 2 +- src/v/kafka/server/tests/metadata_test.cc | 2 +- src/v/kafka/server/tests/offset_commit_test.cc | 2 +- src/v/kafka/server/tests/offset_fetch_test.cc | 2 +- src/v/kafka/server/tests/produce_consume_test.cc | 2 +- src/v/kafka/server/tests/read_write_roundtrip_test.cc | 2 +- src/v/kafka/server/tests/request_parser_test.cc | 2 +- src/v/kafka/server/tests/timeouts_conversion_test.cc | 2 +- src/v/kafka/server/tests/topic_recreate_test.cc | 2 +- src/v/kafka/server/tests/topic_utils_test.cc | 2 +- src/v/kafka/server/tests/types_conversion_tests.cc | 2 +- src/v/kafka/types.h | 2 +- src/v/likely.h | 2 +- src/v/model/adl_serde.cc | 2 +- src/v/model/adl_serde.h | 2 +- src/v/model/async_adl_serde.cc | 2 +- src/v/model/async_adl_serde.h | 2 +- src/v/model/compression.h | 2 +- src/v/model/errc.h | 2 +- src/v/model/fundamental.h | 2 +- src/v/model/limits.h | 2 +- src/v/model/metadata.h | 2 +- src/v/model/model.cc | 2 +- src/v/model/namespace.h | 2 +- src/v/model/record.h | 2 +- src/v/model/record_batch_reader.cc | 2 +- src/v/model/record_batch_reader.h | 2 +- src/v/model/record_batch_types.h | 2 +- src/v/model/record_utils.cc | 2 +- src/v/model/record_utils.h | 2 +- src/v/model/tests/lexical_cast_tests.cc | 2 +- src/v/model/tests/model_serialization_test.cc | 2 +- src/v/model/tests/ntp_path_test.cc | 2 +- src/v/model/tests/record_batch_reader_test.cc | 2 +- src/v/model/tests/record_batch_test.cc | 2 +- src/v/model/tests/topic_view_tests.cc | 2 +- src/v/model/timeout_clock.h | 2 +- src/v/model/timestamp.h | 2 +- src/v/model/validation.cc | 2 +- src/v/model/validation.h | 2 +- src/v/net/batched_output_stream.cc | 2 +- src/v/net/batched_output_stream.h | 2 +- src/v/net/client_probe.h | 2 +- src/v/net/connection.cc | 2 +- src/v/net/connection.h | 2 +- src/v/net/dns.cc | 2 +- src/v/net/dns.h | 2 +- src/v/net/probes.cc | 2 +- src/v/net/server.cc | 2 +- src/v/net/server.h | 2 +- src/v/net/server_probe.h | 2 +- src/v/net/unresolved_address.h | 2 +- src/v/oncore.h | 2 +- src/v/outcome.h | 2 +- src/v/outcome_future_utils.h | 2 +- src/v/outcome_tests.cc | 2 +- src/v/pandaproxy/json/iobuf.h | 2 +- src/v/pandaproxy/json/requests/create_consumer.h | 2 +- src/v/pandaproxy/json/requests/error_reply.h | 2 +- src/v/pandaproxy/json/requests/fetch.h | 2 +- src/v/pandaproxy/json/requests/offset_commit.h | 2 +- src/v/pandaproxy/json/requests/offset_fetch.h | 2 +- src/v/pandaproxy/json/requests/partition_offsets.h | 2 +- src/v/pandaproxy/json/requests/partitions.h | 2 +- src/v/pandaproxy/json/requests/produce.h | 2 +- src/v/pandaproxy/json/requests/subscribe_consumer.h | 2 +- src/v/pandaproxy/json/requests/test/fetch.cc | 2 +- src/v/pandaproxy/json/requests/test/produce.cc | 2 +- src/v/pandaproxy/json/rjson_util.h | 2 +- src/v/pandaproxy/json/test/iobuf.cc | 2 +- src/v/pandaproxy/json/types.h | 2 +- src/v/pandaproxy/logger.cc | 2 +- src/v/pandaproxy/logger.h | 2 +- src/v/pandaproxy/probe.cc | 2 +- src/v/pandaproxy/probe.h | 2 +- src/v/pandaproxy/reply.h | 2 +- src/v/pandaproxy/rest/configuration.cc | 2 +- src/v/pandaproxy/rest/configuration.h | 2 +- src/v/pandaproxy/rest/fwd.h | 2 +- src/v/pandaproxy/rest/handlers.cc | 2 +- src/v/pandaproxy/rest/handlers.h | 2 +- src/v/pandaproxy/rest/proxy.cc | 2 +- src/v/pandaproxy/rest/proxy.h | 2 +- src/v/pandaproxy/rest/test/consumer_group.cc | 2 +- src/v/pandaproxy/rest/test/fetch.cc | 2 +- src/v/pandaproxy/rest/test/list_topics.cc | 2 +- src/v/pandaproxy/rest/test/produce.cc | 2 +- src/v/pandaproxy/schema_registry/test/consume_to_store.cc | 2 +- .../pandaproxy/schema_registry/test/delete_subject_endpoints.cc | 2 +- src/v/pandaproxy/schema_registry/test/get_schema_types.cc | 2 +- src/v/pandaproxy/schema_registry/test/one_shot.cc | 2 +- .../schema_registry/test/post_subjects_subject_version.cc | 2 +- src/v/pandaproxy/server.cc | 2 +- src/v/pandaproxy/server.h | 2 +- src/v/pandaproxy/test/pandaproxy_fixture.h | 2 +- src/v/pandaproxy/test/utils.h | 2 +- src/v/platform/stop_signal.h | 2 +- src/v/prometheus/prometheus_sanitize.h | 2 +- src/v/raft/configuration_bootstrap_state.cc | 2 +- src/v/raft/configuration_bootstrap_state.h | 2 +- src/v/raft/configuration_manager.cc | 2 +- src/v/raft/configuration_manager.h | 2 +- src/v/raft/consensus.cc | 2 +- src/v/raft/consensus.h | 2 +- src/v/raft/consensus_client_protocol.h | 2 +- src/v/raft/consensus_utils.cc | 2 +- src/v/raft/consensus_utils.h | 2 +- src/v/raft/errc.h | 2 +- src/v/raft/event_manager.cc | 2 +- src/v/raft/event_manager.h | 2 +- src/v/raft/follower_queue.cc | 2 +- src/v/raft/follower_queue.h | 2 +- src/v/raft/follower_stats.cc | 2 +- src/v/raft/follower_stats.h | 2 +- src/v/raft/fwd.h | 2 +- src/v/raft/group_configuration.cc | 2 +- src/v/raft/group_configuration.h | 2 +- src/v/raft/group_manager.cc | 2 +- src/v/raft/group_manager.h | 2 +- src/v/raft/heartbeat_manager.cc | 2 +- src/v/raft/heartbeat_manager.h | 2 +- src/v/raft/kvelldb/errc.h | 2 +- src/v/raft/kvelldb/httpkvrsm.cc | 2 +- src/v/raft/kvelldb/httpkvrsm.h | 2 +- src/v/raft/kvelldb/kvrsm.cc | 2 +- src/v/raft/kvelldb/kvrsm.h | 2 +- src/v/raft/kvelldb/kvserver.cc | 2 +- src/v/raft/kvelldb/logger.cc | 2 +- src/v/raft/kvelldb/logger.h | 2 +- src/v/raft/log_eviction_stm.cc | 2 +- src/v/raft/log_eviction_stm.h | 2 +- src/v/raft/logger.cc | 2 +- src/v/raft/logger.h | 2 +- src/v/raft/mux_state_machine.h | 2 +- src/v/raft/offset_monitor.cc | 2 +- src/v/raft/offset_monitor.h | 2 +- src/v/raft/prevote_stm.cc | 2 +- src/v/raft/prevote_stm.h | 2 +- src/v/raft/probe.cc | 2 +- src/v/raft/probe.h | 2 +- src/v/raft/recovery_memory_quota.cc | 2 +- src/v/raft/recovery_memory_quota.h | 2 +- src/v/raft/recovery_stm.cc | 2 +- src/v/raft/recovery_stm.h | 2 +- src/v/raft/recovery_throttle.h | 2 +- src/v/raft/replicate_batcher.cc | 2 +- src/v/raft/replicate_batcher.h | 2 +- src/v/raft/replicate_entries_stm.cc | 2 +- src/v/raft/replicate_entries_stm.h | 2 +- src/v/raft/rpc_client_protocol.cc | 2 +- src/v/raft/rpc_client_protocol.h | 2 +- src/v/raft/service.h | 2 +- src/v/raft/state_machine.cc | 2 +- src/v/raft/state_machine.h | 2 +- src/v/raft/tests/append_entries_test.cc | 2 +- src/v/raft/tests/bootstrap_configuration_test.cc | 2 +- src/v/raft/tests/configuration_manager_test.cc | 2 +- src/v/raft/tests/configuration_serialization_test.cc | 2 +- src/v/raft/tests/consensus_utils_test.cc | 2 +- src/v/raft/tests/foreign_entry_test.cc | 2 +- src/v/raft/tests/group_configuration_tests.cc | 2 +- src/v/raft/tests/jitter_tests.cc | 2 +- src/v/raft/tests/leadership_test.cc | 2 +- src/v/raft/tests/manual_log_deletion_test.cc | 2 +- src/v/raft/tests/membership_test.cc | 2 +- src/v/raft/tests/mux_state_machine_fixture.h | 2 +- src/v/raft/tests/mux_state_machine_test.cc | 2 +- src/v/raft/tests/offset_monitor_test.cc | 2 +- src/v/raft/tests/offset_translator_tests.cc | 2 +- src/v/raft/tests/raft_group_fixture.h | 2 +- src/v/raft/tests/simple_record_fixture.h | 2 +- src/v/raft/tests/state_removal_test.cc | 2 +- src/v/raft/tests/term_assigning_reader_test.cc | 2 +- src/v/raft/tests/type_serialization_tests.cc | 2 +- src/v/raft/timeout_jitter.h | 2 +- src/v/raft/tron/client.cc | 2 +- src/v/raft/tron/logger.cc | 2 +- src/v/raft/tron/logger.h | 2 +- src/v/raft/tron/server.cc | 2 +- src/v/raft/tron/service.h | 2 +- src/v/raft/tron/types.h | 2 +- src/v/raft/types.cc | 2 +- src/v/raft/types.h | 2 +- src/v/raft/vote_stm.cc | 2 +- src/v/raft/vote_stm.h | 2 +- src/v/random/fast_prng.h | 2 +- src/v/random/generators.h | 2 +- src/v/random/random_test.cc | 2 +- src/v/random/simple_time_jitter.h | 2 +- src/v/redpanda/admin_server.cc | 2 +- src/v/redpanda/admin_server.h | 2 +- src/v/redpanda/application.cc | 2 +- src/v/redpanda/application.h | 2 +- src/v/redpanda/main.cc | 2 +- src/v/redpanda/tests/fixture.h | 2 +- src/v/reflection/adl.h | 2 +- src/v/reflection/arity.h | 2 +- src/v/reflection/async_adl.h | 2 +- src/v/reflection/for_each_field.h | 2 +- src/v/reflection/test/arity_test.cc | 2 +- src/v/reflection/test/async_adl_test.cc | 2 +- src/v/reflection/to_tuple.h | 2 +- src/v/reflection/type_traits.h | 2 +- src/v/resource_mgmt/cpu_scheduling.h | 2 +- src/v/resource_mgmt/io_priority.h | 2 +- src/v/resource_mgmt/memory_groups.h | 2 +- src/v/resource_mgmt/rate.h | 2 +- src/v/resource_mgmt/smp_groups.h | 2 +- src/v/rpc/backoff_policy.h | 2 +- src/v/rpc/connection_cache.cc | 2 +- src/v/rpc/connection_cache.h | 2 +- src/v/rpc/demo/client.cc | 2 +- src/v/rpc/demo/demo_utils.h | 2 +- src/v/rpc/demo/server.cc | 2 +- src/v/rpc/demo/type_tests.cc | 2 +- src/v/rpc/demo/types.h | 2 +- src/v/rpc/errc.h | 2 +- src/v/rpc/exceptions.h | 2 +- src/v/rpc/logger.h | 2 +- src/v/rpc/netbuf.cc | 2 +- src/v/rpc/parse_utils.h | 2 +- src/v/rpc/reconnect_transport.cc | 2 +- src/v/rpc/reconnect_transport.h | 2 +- src/v/rpc/response_handler.h | 2 +- src/v/rpc/service.h | 2 +- src/v/rpc/simple_protocol.cc | 2 +- src/v/rpc/simple_protocol.h | 2 +- src/v/rpc/test/exponential_backoff.cc | 2 +- src/v/rpc/test/netbuf_tests.cc | 2 +- src/v/rpc/test/response_handler_tests.cc | 2 +- src/v/rpc/test/roundtrip_tests.cc | 2 +- src/v/rpc/test/rpc_bench.cc | 2 +- src/v/rpc/test/rpc_gen_cycling_test.cc | 2 +- src/v/rpc/test/rpc_gen_types.h | 2 +- src/v/rpc/test/rpc_integration_fixture.h | 2 +- src/v/rpc/test/serialization_test.cc | 2 +- src/v/rpc/test/test_types.h | 2 +- src/v/rpc/transport.cc | 2 +- src/v/rpc/transport.h | 2 +- src/v/rpc/types.cc | 2 +- src/v/rpc/types.h | 2 +- src/v/s3/client.cc | 2 +- src/v/s3/client.h | 2 +- src/v/s3/client_probe.cc | 2 +- src/v/s3/client_probe.h | 2 +- src/v/s3/error.cc | 2 +- src/v/s3/error.h | 2 +- src/v/s3/logger.h | 2 +- src/v/s3/signature.cc | 2 +- src/v/s3/signature.h | 2 +- src/v/s3/test_client/s3_test_client_main.cc | 2 +- src/v/s3/tests/s3_client_test.cc | 2 +- src/v/s3/tests/signature_test.cc | 2 +- src/v/seastarx.h | 2 +- src/v/security/credential_store.h | 2 +- src/v/security/errc.h | 2 +- src/v/security/logger.h | 2 +- src/v/security/sasl_authentication.h | 2 +- src/v/security/scram_algorithm.h | 2 +- src/v/security/scram_authenticator.cc | 2 +- src/v/security/scram_authenticator.h | 2 +- src/v/security/tests/authorizer_test.cc | 2 +- src/v/security/tests/credential_store_test.cc | 2 +- src/v/security/tests/scram_algorithm_test.cc | 2 +- src/v/serde/test/bench.cc | 2 +- src/v/ssx/future-util.h | 2 +- src/v/ssx/sformat.h | 2 +- src/v/ssx/tests/async_transforms.cc | 2 +- src/v/ssx/tests/sformat.cc | 2 +- src/v/ssx/tests/sformat_bench.cc | 2 +- src/v/static_deleter_fn.h | 2 +- src/v/storage/api.h | 2 +- src/v/storage/backlog_controller.cc | 2 +- src/v/storage/backlog_controller.h | 2 +- src/v/storage/batch_cache.cc | 2 +- src/v/storage/batch_cache.h | 2 +- src/v/storage/compacted_index.h | 2 +- src/v/storage/compacted_index_chunk_reader.cc | 2 +- src/v/storage/compacted_index_chunk_reader.h | 2 +- src/v/storage/compacted_index_reader.h | 2 +- src/v/storage/compacted_index_writer.h | 2 +- src/v/storage/compacted_offset_list.h | 2 +- src/v/storage/compaction_controller.cc | 2 +- src/v/storage/compaction_controller.h | 2 +- src/v/storage/compaction_reducers.cc | 2 +- src/v/storage/compaction_reducers.h | 2 +- src/v/storage/directories.h | 2 +- src/v/storage/disk_log_appender.cc | 2 +- src/v/storage/disk_log_appender.h | 2 +- src/v/storage/disk_log_impl.cc | 2 +- src/v/storage/disk_log_impl.h | 2 +- src/v/storage/exceptions.h | 2 +- src/v/storage/failure_probes.h | 2 +- src/v/storage/fs_utils.h | 2 +- src/v/storage/fwd.h | 2 +- src/v/storage/index_state.cc | 2 +- src/v/storage/index_state.h | 2 +- src/v/storage/kvstore.cc | 2 +- src/v/storage/kvstore.h | 2 +- src/v/storage/lock_manager.cc | 2 +- src/v/storage/lock_manager.h | 2 +- src/v/storage/log.h | 2 +- src/v/storage/log_appender.h | 2 +- src/v/storage/log_housekeeping_meta.h | 2 +- src/v/storage/log_manager.cc | 2 +- src/v/storage/log_manager.h | 2 +- src/v/storage/log_reader.cc | 2 +- src/v/storage/log_reader.h | 2 +- src/v/storage/log_replayer.cc | 2 +- src/v/storage/log_replayer.h | 2 +- src/v/storage/logger.cc | 2 +- src/v/storage/logger.h | 2 +- src/v/storage/mem_log_impl.cc | 2 +- src/v/storage/ntp_config.h | 2 +- src/v/storage/offset_assignment.h | 2 +- src/v/storage/offset_to_filepos_consumer.h | 2 +- src/v/storage/opfuzz/opfuzz.cc | 2 +- src/v/storage/opfuzz/opfuzz.h | 2 +- src/v/storage/opfuzz/opfuzz_test.cc | 2 +- src/v/storage/parser.cc | 2 +- src/v/storage/parser.h | 2 +- src/v/storage/parser_errc.h | 2 +- src/v/storage/parser_utils.cc | 2 +- src/v/storage/parser_utils.h | 2 +- src/v/storage/probe.cc | 2 +- src/v/storage/probe.h | 2 +- src/v/storage/readers_cache.cc | 2 +- src/v/storage/readers_cache.h | 2 +- src/v/storage/record_batch_builder.cc | 2 +- src/v/storage/record_batch_builder.h | 2 +- src/v/storage/segment.cc | 2 +- src/v/storage/segment.h | 2 +- src/v/storage/segment_appender.cc | 2 +- src/v/storage/segment_appender.h | 2 +- src/v/storage/segment_appender_chunk.h | 2 +- src/v/storage/segment_appender_utils.cc | 2 +- src/v/storage/segment_appender_utils.h | 2 +- src/v/storage/segment_index.cc | 2 +- src/v/storage/segment_index.h | 2 +- src/v/storage/segment_reader.cc | 2 +- src/v/storage/segment_reader.h | 2 +- src/v/storage/segment_set.cc | 2 +- src/v/storage/segment_set.h | 2 +- src/v/storage/segment_utils.cc | 2 +- src/v/storage/segment_utils.h | 2 +- src/v/storage/shard_assignment.h | 2 +- src/v/storage/snapshot.cc | 2 +- src/v/storage/snapshot.h | 2 +- src/v/storage/spill_key_index.cc | 2 +- src/v/storage/spill_key_index.h | 2 +- src/v/storage/tests/appender_chunk_manipulations.cc | 2 +- src/v/storage/tests/backlog_controller_test.cc | 2 +- src/v/storage/tests/batch_cache_reclaim_test.cc | 2 +- src/v/storage/tests/batch_cache_test.cc | 2 +- src/v/storage/tests/compaction_idx_bench.cc | 2 +- src/v/storage/tests/compaction_index_format_tests.cc | 2 +- src/v/storage/tests/disk_log_builder_fixture.h | 2 +- src/v/storage/tests/disk_log_builder_test.cc | 2 +- src/v/storage/tests/half_page_concurrent_dispatch.cc | 2 +- src/v/storage/tests/kvstore_test.cc | 2 +- src/v/storage/tests/log_manager_test.cc | 2 +- src/v/storage/tests/log_replayer_test.cc | 2 +- src/v/storage/tests/log_retention_tests.cc | 2 +- src/v/storage/tests/log_segment_appender_test.cc | 2 +- src/v/storage/tests/log_segment_reader_test.cc | 2 +- src/v/storage/tests/log_truncate_test.cc | 2 +- src/v/storage/tests/offset_assignment_test.cc | 2 +- src/v/storage/tests/offset_index_utils_tests.cc | 2 +- src/v/storage/tests/produce_consume_test.cc | 2 +- src/v/storage/tests/record_batch_builder_test.cc | 2 +- src/v/storage/tests/segment_size_jitter_test.cc | 2 +- src/v/storage/tests/snapshot_test.cc | 2 +- src/v/storage/tests/storage_e2e_test.cc | 2 +- src/v/storage/tests/storage_test_fixture.h | 2 +- src/v/storage/tests/timequery_test.cc | 2 +- src/v/storage/tests/utils/disk_log_builder.cc | 2 +- src/v/storage/tests/utils/disk_log_builder.h | 2 +- src/v/storage/tests/utils/random_batch.cc | 2 +- src/v/storage/tests/utils/random_batch.h | 2 +- src/v/storage/types.cc | 2 +- src/v/storage/types.h | 2 +- src/v/storage/utils/transforming_reader.h | 2 +- src/v/storage/version.h | 2 +- src/v/syschecks/pidfile.cc | 2 +- src/v/syschecks/syschecks.cc | 2 +- src/v/syschecks/syschecks.h | 2 +- src/v/test_utils/async.h | 2 +- src/v/test_utils/fixture.h | 2 +- src/v/test_utils/logs.h | 2 +- src/v/test_utils/non_root_port.h | 2 +- src/v/test_utils/randoms.h | 2 +- src/v/test_utils/rpc.h | 2 +- src/v/test_utils/seastar_testing_main.cc | 2 +- src/v/test_utils/tmp_dir.h | 2 +- src/v/tristate.h | 2 +- src/v/units.h | 2 +- src/v/utils/absl_sstring_hash.h | 2 +- src/v/utils/available_promise.h | 2 +- src/v/utils/base64.cc | 2 +- src/v/utils/base64.h | 2 +- src/v/utils/concepts-enabled.h | 2 +- src/v/utils/copy_range.h | 2 +- src/v/utils/directory_walker.h | 2 +- src/v/utils/expiring_promise.h | 2 +- src/v/utils/file_io.cc | 2 +- src/v/utils/file_io.h | 2 +- src/v/utils/file_sanitizer.h | 2 +- src/v/utils/fragmented_vector.h | 2 +- src/v/utils/functional.h | 2 +- src/v/utils/hdr_hist.cc | 2 +- src/v/utils/hdr_hist.h | 2 +- src/v/utils/human.cc | 2 +- src/v/utils/human.h | 2 +- src/v/utils/intrusive_list_helpers.h | 2 +- src/v/utils/memory_data_source.h | 2 +- src/v/utils/mutex.h | 2 +- src/v/utils/named_type.h | 2 +- src/v/utils/remote.h | 2 +- src/v/utils/retry.h | 2 +- src/v/utils/retry_chain_node.cc | 2 +- src/v/utils/retry_chain_node.h | 2 +- src/v/utils/string_switch.h | 2 +- src/v/utils/tests/base64_test.cc | 2 +- src/v/utils/tests/constexpr_string_switch.cc | 2 +- src/v/utils/tests/directory_walker_test.cc | 2 +- src/v/utils/tests/named_type_tests.cc | 2 +- src/v/utils/tests/outcome_utils_test.cc | 2 +- src/v/utils/tests/remote_test.cc | 2 +- src/v/utils/tests/retry_chain_node_test.cc | 2 +- src/v/utils/tests/retry_test.cc | 2 +- src/v/utils/tests/string_switch_test.cc | 2 +- src/v/utils/tests/tristate_test.cc | 2 +- src/v/utils/tests/vint_test.cc | 2 +- src/v/utils/tests/waiter_queue_test.cc | 2 +- src/v/utils/timed_mutex.h | 2 +- src/v/utils/to_string.h | 2 +- src/v/utils/utf8.h | 2 +- src/v/utils/vint.h | 2 +- src/v/vassert.h | 2 +- src/v/vlog.h | 2 +- tests/rptest/__init__.py | 2 +- tests/rptest/clients/__init__.py | 2 +- tests/rptest/clients/compacted_verifier.py | 2 +- tests/rptest/clients/kafka_cat.py | 2 +- tests/rptest/clients/kafka_cli_tools.py | 2 +- tests/rptest/clients/python_librdkafka.py | 2 +- tests/rptest/clients/rpk.py | 2 +- tests/rptest/services/__init__.py | 2 +- tests/rptest/services/compatibility/__init__.py | 2 +- tests/rptest/services/failure_injector.py | 2 +- tests/rptest/services/http_server.py | 2 +- tests/rptest/services/kaf_consumer.py | 2 +- tests/rptest/services/kaf_producer.py | 2 +- tests/rptest/services/redpanda.py | 2 +- tests/rptest/services/rpk_consumer.py | 2 +- tests/rptest/services/storage.py | 2 +- tests/rptest/services/templates/redpanda.yaml | 2 +- tests/rptest/test_suite_all.yml | 2 +- tests/rptest/test_suite_pandaproxy.yml | 2 +- tests/rptest/test_suite_quick.yml | 2 +- tests/rptest/test_suite_wasm.yml | 2 +- tests/rptest/tests/__init__.py | 2 +- tests/rptest/tests/admin_api_auth_test.py | 2 +- tests/rptest/tests/alter_topic_configuration_test.py | 2 +- tests/rptest/tests/availability_test.py | 2 +- tests/rptest/tests/cluster_config_test.py | 2 +- tests/rptest/tests/cluster_metadata_test.py | 2 +- tests/rptest/tests/cluster_view_test.py | 2 +- tests/rptest/tests/compacted_term_rolled_recovery_test.py | 2 +- tests/rptest/tests/compacted_topic_verifier_test.py | 2 +- tests/rptest/tests/compaction_recovery_test.py | 2 +- tests/rptest/tests/compatibility/__init__.py | 2 +- tests/rptest/tests/compatibility/sarama_produce_test.py | 2 +- tests/rptest/tests/configuration_update_test.py | 2 +- tests/rptest/tests/controller_recovery_test.py | 2 +- tests/rptest/tests/create_partitions_test.py | 2 +- tests/rptest/tests/custom_topic_assignment_test.py | 2 +- tests/rptest/tests/describe_topics_test.py | 2 +- tests/rptest/tests/e2e_finjector.py | 2 +- tests/rptest/tests/fetch_after_deletion_test.py | 2 +- tests/rptest/tests/fetch_fairness_test.py | 2 +- tests/rptest/tests/full_node_recovery_test.py | 2 +- tests/rptest/tests/idempotency_test.py | 2 +- tests/rptest/tests/kafka_cli_client_compat_test.py | 2 +- tests/rptest/tests/leadership_transfer_test.py | 2 +- tests/rptest/tests/librdkafka_test.py | 2 +- tests/rptest/tests/log_level_test.py | 2 +- tests/rptest/tests/metrics_reporter_test.py | 2 +- tests/rptest/tests/multi_restarts_with_archival_test.py | 2 +- tests/rptest/tests/node_operations_fuzzy_test.py | 2 +- tests/rptest/tests/nodes_decommissioning_test.py | 2 +- tests/rptest/tests/pandaproxy_test.py | 2 +- tests/rptest/tests/partition_movement.py | 2 +- tests/rptest/tests/partition_movement_test.py | 2 +- tests/rptest/tests/prefix_truncate_recovery_test.py | 2 +- tests/rptest/tests/raft_availability_test.py | 2 +- tests/rptest/tests/recreate_topic_metadata_test.py | 2 +- tests/rptest/tests/redpanda_test.py | 2 +- tests/rptest/tests/retention_policy_test.py | 2 +- tests/rptest/tests/rpk_topic_test.py | 2 +- tests/rptest/tests/scaling_up_test.py | 2 +- tests/rptest/tests/scram_pythonlib_test.py | 2 +- tests/rptest/tests/scram_test.py | 2 +- tests/rptest/tests/scramful_eos_test.py | 2 +- tests/rptest/tests/scramless_eos_test.py | 2 +- tests/rptest/tests/topic_delete_test.py | 2 +- tests/rptest/tests/tx_reads_writes_test.py | 2 +- tests/rptest/tests/tx_verifier_test.py | 2 +- tests/rptest/tests/wait_for_local_consumer_test.py | 2 +- tests/rptest/util.py | 2 +- tools/cmake_test.py | 2 +- tools/kafka-python-api-serde.py | 2 +- tools/rpcgen.py | 2 +- tools/ts-generator/example/demo.ts | 2 +- tools/ts-generator/example/functions.ts | 2 +- tools/ts-generator/rpc/example/demo.ts | 2 +- tools/ts-generator/rpc/example/functions.ts | 2 +- tools/ts-generator/rpc/example/generatedServer.ts | 2 +- tools/ts-generator/rpc/example/generatedType.ts | 2 +- tools/ts-generator/rpc/rpc_gen_js.py | 2 +- tools/ts-generator/types/functions.ts | 2 +- tools/ts-generator/types/test.ts | 2 +- tools/ts-generator/types/types_gen_js.py | 2 +- 1195 files changed, 1195 insertions(+), 1195 deletions(-) diff --git a/.dir-locals.el b/.dir-locals.el index 1fbce4522358..0fb582ae2b00 100644 --- a/.dir-locals.el +++ b/.dir-locals.el @@ -1,4 +1,4 @@ -;; Copyright 2020 Vectorized, Inc. +;; Copyright 2020 Redpanda Data, Inc. ;; ;; Use of this software is governed by the Business Source License ;; included in the file licenses/BSL.md diff --git a/.github/workflows/homebrew-publish.yml b/.github/workflows/homebrew-publish.yml index bb6ee3b56822..994b9a436fd7 100644 --- a/.github/workflows/homebrew-publish.yml +++ b/.github/workflows/homebrew-publish.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/.github/workflows/lint.yml b/.github/workflows/lint.yml index 9e2077983b17..c727a7505437 100644 --- a/.github/workflows/lint.yml +++ b/.github/workflows/lint.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/.github/workflows/redpanda-build.yml b/.github/workflows/redpanda-build.yml index 3b6ba703df1e..070846cb7494 100644 --- a/.github/workflows/redpanda-build.yml +++ b/.github/workflows/redpanda-build.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/.github/workflows/rpk-build.yml b/.github/workflows/rpk-build.yml index 92e96563ac7c..96a1bffeba66 100644 --- a/.github/workflows/rpk-build.yml +++ b/.github/workflows/rpk-build.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/.github/workflows/wasm-publish.yml b/.github/workflows/wasm-publish.yml index 6061d23f842e..fd52482679a1 100644 --- a/.github/workflows/wasm-publish.yml +++ b/.github/workflows/wasm-publish.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/build.sh b/build.sh index 3999474c78db..2e0552dc2223 100755 --- a/build.sh +++ b/build.sh @@ -1,5 +1,5 @@ #!/bin/bash -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/conf/redpanda.yaml b/conf/redpanda.yaml index 8c32c11e022e..ae98dc3d4c37 100644 --- a/conf/redpanda.yaml +++ b/conf/redpanda.yaml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/install-dependencies.sh b/install-dependencies.sh index a6ff166f6db7..c6370e4d3b03 100755 --- a/install-dependencies.sh +++ b/install-dependencies.sh @@ -1,5 +1,5 @@ #!/bin/bash -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/licenses/bsl_header.txt b/licenses/bsl_header.txt index fe1306727d2a..f3094359412c 100644 --- a/licenses/bsl_header.txt +++ b/licenses/bsl_header.txt @@ -1,4 +1,4 @@ -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/licenses/rcl_header.txt b/licenses/rcl_header.txt index 77e601306405..6d41e7beced4 100644 --- a/licenses/rcl_header.txt +++ b/licenses/rcl_header.txt @@ -1,4 +1,4 @@ -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Licensed as a Redpanda Enterprise file under the Redpanda Community License (the "License"); you may not use this file except in compliance with diff --git a/src/consistency-testing/iofaults/iofaults.py b/src/consistency-testing/iofaults/iofaults.py index 30010ec843d8..35ee5b5fa38f 100755 --- a/src/consistency-testing/iofaults/iofaults.py +++ b/src/consistency-testing/iofaults/iofaults.py @@ -1,5 +1,5 @@ #!/usr/bin/env python -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/ci/ct.yaml b/src/go/k8s/helm-chart/charts/ci/ct.yaml index ebb524f672f4..45cb7cceddb2 100644 --- a/src/go/k8s/helm-chart/charts/ci/ct.yaml +++ b/src/go/k8s/helm-chart/charts/ci/ct.yaml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/NOTES.txt b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/NOTES.txt index ad56c3e5625e..71bf6666048d 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/NOTES.txt +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/NOTES.txt @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/_helpers.tpl b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/_helpers.tpl index 1b08b00f1df6..65b932d8db55 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/_helpers.tpl +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/_helpers.tpl @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/certificate.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/certificate.yaml index cff0f75529b1..8244a537bafc 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/certificate.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/certificate.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole.yaml index a425994c7c35..83d6d0c4eeb8 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_binding.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_binding.yaml index c241c0371b06..9c865e1e63a6 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_binding.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_binding.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_metrics.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_metrics.yaml index 8d46c6a5e79a..e954060bcb00 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_metrics.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_metrics.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy.yaml index f72422803aa3..ca9971dfb4cb 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy_binding.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy_binding.yaml index 852f044617ac..906463e08d61 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy_binding.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/clusterrole_proxy_binding.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/configmap.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/configmap.yaml index a760a8253dd2..44d6fab460ef 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/configmap.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/configmap.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/deployment.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/deployment.yaml index c48d67ed56e5..367d557ae857 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/deployment.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/deployment.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/issuer.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/issuer.yaml index e98ddf72847b..deaabaa2d134 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/issuer.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/issuer.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/mutating_webhook.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/mutating_webhook.yaml index 77113a48a0c8..d486558725f6 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/mutating_webhook.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/mutating_webhook.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role.yaml index e211a1a9224c..f897a8b9bac9 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role_binding.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role_binding.yaml index e0481e4c8b56..69a50282d7ab 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role_binding.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/role_binding.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_account.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_account.yaml index b1f7390d1002..ca00c491f642 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_account.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_account.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_metrics.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_metrics.yaml index 9ba0117fd9bb..8d0c59ab7aee 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_metrics.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_metrics.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_webhook.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_webhook.yaml index c9ff550eaa6d..5482fb87172d 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_webhook.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/service_webhook.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/servicemonitor.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/servicemonitor.yaml index ca44144bd828..942a5ed110b2 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/servicemonitor.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/servicemonitor.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/validating_webhook.yaml b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/validating_webhook.yaml index 3bce17b097b2..c3028aaae030 100644 --- a/src/go/k8s/helm-chart/charts/redpanda-operator/templates/validating_webhook.yaml +++ b/src/go/k8s/helm-chart/charts/redpanda-operator/templates/validating_webhook.yaml @@ -1,5 +1,5 @@ {{/* -Copyright 2020 Vectorized, Inc. +Copyright 2020 Redpanda Data, Inc. Use of this software is governed by the Business Source License included in the file licenses/BSL.md diff --git a/src/go/rpk/build.sh b/src/go/rpk/build.sh index 49a4e67faf8d..0bc3fca4ac3a 100755 --- a/src/go/rpk/build.sh +++ b/src/go/rpk/build.sh @@ -1,5 +1,5 @@ #!/bin/bash -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/go/rpk/cmd/rpk/main.go b/src/go/rpk/cmd/rpk/main.go index e3021326607d..9897f62e8fbd 100644 --- a/src/go/rpk/cmd/rpk/main.go +++ b/src/go/rpk/cmd/rpk/main.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/api.go b/src/go/rpk/pkg/api/api.go index eb85e4dddd57..8c312af7365f 100644 --- a/src/go/rpk/pkg/api/api.go +++ b/src/go/rpk/pkg/api/api.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/api_test.go b/src/go/rpk/pkg/api/api_test.go index eca5226893a2..391df136ff6a 100644 --- a/src/go/rpk/pkg/api/api_test.go +++ b/src/go/rpk/pkg/api/api_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/container.go b/src/go/rpk/pkg/cli/cmd/container.go index d5b643070f31..6229d38d0ad0 100644 --- a/src/go/rpk/pkg/cli/cmd/container.go +++ b/src/go/rpk/pkg/cli/cmd/container.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 d188df93df3f..b6f57a9d5c89 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/client.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/client.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 d2c62496e175..7e805a432782 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/common.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/common.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 5baa676fcbac..4894856e8bd0 100644 --- a/src/go/rpk/pkg/cli/cmd/container/common/test.go +++ b/src/go/rpk/pkg/cli/cmd/container/common/test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/container/purge.go b/src/go/rpk/pkg/cli/cmd/container/purge.go index 7a691ddd4d73..233bc8e7ec51 100644 --- a/src/go/rpk/pkg/cli/cmd/container/purge.go +++ b/src/go/rpk/pkg/cli/cmd/container/purge.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 37e0761216a9..9b48660386b1 100644 --- a/src/go/rpk/pkg/cli/cmd/container/purge_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/purge_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/container/start.go b/src/go/rpk/pkg/cli/cmd/container/start.go index 45cd1044bd36..d8699179ca34 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start.go +++ b/src/go/rpk/pkg/cli/cmd/container/start.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 4a8010f91a57..18239f8acbe0 100644 --- a/src/go/rpk/pkg/cli/cmd/container/start_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/start_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/container/stop.go b/src/go/rpk/pkg/cli/cmd/container/stop.go index f2be75d14cf7..5659317559d2 100644 --- a/src/go/rpk/pkg/cli/cmd/container/stop.go +++ b/src/go/rpk/pkg/cli/cmd/container/stop.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 1f9f121e131b..d4493f0c0e91 100644 --- a/src/go/rpk/pkg/cli/cmd/container/stop_test.go +++ b/src/go/rpk/pkg/cli/cmd/container/stop_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/generate.go b/src/go/rpk/pkg/cli/cmd/generate.go index 8a29f5bdd187..eff80eaa1b1c 100644 --- a/src/go/rpk/pkg/cli/cmd/generate.go +++ b/src/go/rpk/pkg/cli/cmd/generate.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/generate/autocomplete.go b/src/go/rpk/pkg/cli/cmd/generate/autocomplete.go index 8652b63e290f..d664e0482918 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/autocomplete.go +++ b/src/go/rpk/pkg/cli/cmd/generate/autocomplete.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 3ecc5fbcc000..50fc5f76aa7a 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/dashboard.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 ff42041240a9..ba5b5fb175fe 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 cbacda7b5f37..b9a229e11be6 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/graph.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 062405dcaf88..e87656fdf3e1 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 79222773879f..47d819e88687 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/row.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/row.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 95b3d0fb38db..81c5dc280882 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 e97f3b39a3cb..6fc9c200604a 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/singlestat.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 759aec973ec4..f7ba3fa6bd81 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 92c9d02e24f6..671d72051bcc 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/graf/text.go +++ b/src/go/rpk/pkg/cli/cmd/generate/graf/text.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/generate/grafana.go b/src/go/rpk/pkg/cli/cmd/generate/grafana.go index 0d482f85a877..43d1dc431278 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/grafana.go +++ b/src/go/rpk/pkg/cli/cmd/generate/grafana.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 1610b3ccaa8b..0c904ca7b98c 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go +++ b/src/go/rpk/pkg/cli/cmd/generate/grafana_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/generate/prometheus.go b/src/go/rpk/pkg/cli/cmd/generate/prometheus.go index a25580f67cf9..ddac151a7fa0 100644 --- a/src/go/rpk/pkg/cli/cmd/generate/prometheus.go +++ b/src/go/rpk/pkg/cli/cmd/generate/prometheus.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/iotune.go b/src/go/rpk/pkg/cli/cmd/iotune.go index 89232ba88944..09797f140fe6 100644 --- a/src/go/rpk/pkg/cli/cmd/iotune.go +++ b/src/go/rpk/pkg/cli/cmd/iotune.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/iotune_test.go b/src/go/rpk/pkg/cli/cmd/iotune_test.go index bbfabd16149d..677eb2f3ccb9 100644 --- a/src/go/rpk/pkg/cli/cmd/iotune_test.go +++ b/src/go/rpk/pkg/cli/cmd/iotune_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/root.go b/src/go/rpk/pkg/cli/cmd/root.go index 80aeef77a495..44b6b427fbd9 100644 --- a/src/go/rpk/pkg/cli/cmd/root.go +++ b/src/go/rpk/pkg/cli/cmd/root.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/root_darwin.go b/src/go/rpk/pkg/cli/cmd/root_darwin.go index 4324d1f43fe9..f9ae5790f3cf 100644 --- a/src/go/rpk/pkg/cli/cmd/root_darwin.go +++ b/src/go/rpk/pkg/cli/cmd/root_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/root_linux.go b/src/go/rpk/pkg/cli/cmd/root_linux.go index ed93a3e450d6..10bf678ab052 100644 --- a/src/go/rpk/pkg/cli/cmd/root_linux.go +++ b/src/go/rpk/pkg/cli/cmd/root_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/status.go b/src/go/rpk/pkg/cli/cmd/status.go index 87fd7cdc6d90..834cd0bd723c 100644 --- a/src/go/rpk/pkg/cli/cmd/status.go +++ b/src/go/rpk/pkg/cli/cmd/status.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/version.go b/src/go/rpk/pkg/cli/cmd/version.go index 1378dd6c98a1..de67ec4cc4e6 100644 --- a/src/go/rpk/pkg/cli/cmd/version.go +++ b/src/go/rpk/pkg/cli/cmd/version.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/version/version.go b/src/go/rpk/pkg/cli/cmd/version/version.go index d79b345bd605..8e08597b1d8f 100644 --- a/src/go/rpk/pkg/cli/cmd/version/version.go +++ b/src/go/rpk/pkg/cli/cmd/version/version.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/wasm.go b/src/go/rpk/pkg/cli/cmd/wasm.go index 86e24bc9acc7..f826880b9e38 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm.go +++ b/src/go/rpk/pkg/cli/cmd/wasm.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/wasm/generate.go b/src/go/rpk/pkg/cli/cmd/wasm/generate.go index 4af7ce68fc29..2afeb4264e46 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/generate.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/generate.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/wasm/generate_test.go b/src/go/rpk/pkg/cli/cmd/wasm/generate_test.go index 7ca6e00d83c6..1943cb69b053 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/generate_test.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/generate_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 476115c93a1f..a7e2eb0ba54f 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 c0d81dee7401..2a8c76bc5e37 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/wasm.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 88d03829160b..bcceaaf763d4 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 9a6a9874e87a..7da379cea404 100644 --- a/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go +++ b/src/go/rpk/pkg/cli/cmd/wasm/template/webpack.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/flags.go b/src/go/rpk/pkg/cli/flags.go index feb18fe02d02..206a421f1d16 100644 --- a/src/go/rpk/pkg/cli/flags.go +++ b/src/go/rpk/pkg/cli/flags.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/log_formatter.go b/src/go/rpk/pkg/cli/log_formatter.go index 20b3f2af73d3..a35c442bca57 100644 --- a/src/go/rpk/pkg/cli/log_formatter.go +++ b/src/go/rpk/pkg/cli/log_formatter.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/ui/tables.go b/src/go/rpk/pkg/cli/ui/tables.go index 54d5e1891df4..27154c66b010 100644 --- a/src/go/rpk/pkg/cli/ui/tables.go +++ b/src/go/rpk/pkg/cli/ui/tables.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cloud/aws/aws.go b/src/go/rpk/pkg/cloud/aws/aws.go index 5c7164c85d87..c8f91eac6c8a 100644 --- a/src/go/rpk/pkg/cloud/aws/aws.go +++ b/src/go/rpk/pkg/cloud/aws/aws.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cloud/gcp/gcp.go b/src/go/rpk/pkg/cloud/gcp/gcp.go index c0fc476b0b88..4d134a41579b 100644 --- a/src/go/rpk/pkg/cloud/gcp/gcp.go +++ b/src/go/rpk/pkg/cloud/gcp/gcp.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cloud/vendor/vendor.go b/src/go/rpk/pkg/cloud/vendor/vendor.go index cd8a798df08f..52eb48b8aa7d 100644 --- a/src/go/rpk/pkg/cloud/vendor/vendor.go +++ b/src/go/rpk/pkg/cloud/vendor/vendor.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cloud/vendors.go b/src/go/rpk/pkg/cloud/vendors.go index 5f3c31093ae2..b11cfa39b254 100644 --- a/src/go/rpk/pkg/cloud/vendors.go +++ b/src/go/rpk/pkg/cloud/vendors.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cloud/vendors_test.go b/src/go/rpk/pkg/cloud/vendors_test.go index 9958626997ff..965e21176836 100644 --- a/src/go/rpk/pkg/cloud/vendors_test.go +++ b/src/go/rpk/pkg/cloud/vendors_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/config.go b/src/go/rpk/pkg/config/config.go index b312e001195c..02fd95f327c4 100644 --- a/src/go/rpk/pkg/config/config.go +++ b/src/go/rpk/pkg/config/config.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/config_test.go b/src/go/rpk/pkg/config/config_test.go index 543dd2b14f6f..cecb27b62ba3 100644 --- a/src/go/rpk/pkg/config/config_test.go +++ b/src/go/rpk/pkg/config/config_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/find.go b/src/go/rpk/pkg/config/find.go index a42341374a91..d32c893019ce 100644 --- a/src/go/rpk/pkg/config/find.go +++ b/src/go/rpk/pkg/config/find.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/find_test.go b/src/go/rpk/pkg/config/find_test.go index d1a191624737..bf6dbeb73058 100644 --- a/src/go/rpk/pkg/config/find_test.go +++ b/src/go/rpk/pkg/config/find_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/license.go b/src/go/rpk/pkg/config/license.go index ec6aeb04011c..7577a9197792 100644 --- a/src/go/rpk/pkg/config/license.go +++ b/src/go/rpk/pkg/config/license.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/license_test.go b/src/go/rpk/pkg/config/license_test.go index 7c52f0689c51..12d16f4a7a4d 100644 --- a/src/go/rpk/pkg/config/license_test.go +++ b/src/go/rpk/pkg/config/license_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/manager.go b/src/go/rpk/pkg/config/manager.go index f18e7d959ad5..e12dfab84ec5 100644 --- a/src/go/rpk/pkg/config/manager.go +++ b/src/go/rpk/pkg/config/manager.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/params.go b/src/go/rpk/pkg/config/params.go index 0e5ddb98b3ff..9a06f2b5777e 100644 --- a/src/go/rpk/pkg/config/params.go +++ b/src/go/rpk/pkg/config/params.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/config/schema.go b/src/go/rpk/pkg/config/schema.go index 4707331cf8de..9cd281542190 100644 --- a/src/go/rpk/pkg/config/schema.go +++ b/src/go/rpk/pkg/config/schema.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/kafka/client_franz.go b/src/go/rpk/pkg/kafka/client_franz.go index 4d4801fea761..b275184617de 100644 --- a/src/go/rpk/pkg/kafka/client_franz.go +++ b/src/go/rpk/pkg/kafka/client_franz.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/net/interfaces.go b/src/go/rpk/pkg/net/interfaces.go index 7c2d763d414d..befda3f28cb2 100644 --- a/src/go/rpk/pkg/net/interfaces.go +++ b/src/go/rpk/pkg/net/interfaces.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/os/commands.go b/src/go/rpk/pkg/os/commands.go index 9efa770f8a55..4cb166cf943f 100644 --- a/src/go/rpk/pkg/os/commands.go +++ b/src/go/rpk/pkg/os/commands.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/os/lock.go b/src/go/rpk/pkg/os/lock.go index d60583a3ecf3..aacd46455b23 100644 --- a/src/go/rpk/pkg/os/lock.go +++ b/src/go/rpk/pkg/os/lock.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/os/proc.go b/src/go/rpk/pkg/os/proc.go index 1fb49ac414aa..6d4ec6a7e3af 100644 --- a/src/go/rpk/pkg/os/proc.go +++ b/src/go/rpk/pkg/os/proc.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/os/proc_test.go b/src/go/rpk/pkg/os/proc_test.go index 9c31d2a021c2..6a1b769c5c1e 100644 --- a/src/go/rpk/pkg/os/proc_test.go +++ b/src/go/rpk/pkg/os/proc_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/out/out.go b/src/go/rpk/pkg/out/out.go index d007bdf312f2..1b38196a8e0b 100644 --- a/src/go/rpk/pkg/out/out.go +++ b/src/go/rpk/pkg/out/out.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/redpanda/launcher.go b/src/go/rpk/pkg/redpanda/launcher.go index e0a988a04d4c..f4b83cd94e3a 100644 --- a/src/go/rpk/pkg/redpanda/launcher.go +++ b/src/go/rpk/pkg/redpanda/launcher.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/redpanda/launcher_test.go b/src/go/rpk/pkg/redpanda/launcher_test.go index d506c374eaff..7f994ac5b331 100644 --- a/src/go/rpk/pkg/redpanda/launcher_test.go +++ b/src/go/rpk/pkg/redpanda/launcher_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/redpanda/paths.go b/src/go/rpk/pkg/redpanda/paths.go index 3ddf3635c227..d5cc62499605 100644 --- a/src/go/rpk/pkg/redpanda/paths.go +++ b/src/go/rpk/pkg/redpanda/paths.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/cgroup.go b/src/go/rpk/pkg/system/cgroup.go index 61c1f5ab8f74..820f39b79af4 100644 --- a/src/go/rpk/pkg/system/cgroup.go +++ b/src/go/rpk/pkg/system/cgroup.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/cgroup_test.go b/src/go/rpk/pkg/system/cgroup_test.go index 70e88af3199d..84b73a572806 100644 --- a/src/go/rpk/pkg/system/cgroup_test.go +++ b/src/go/rpk/pkg/system/cgroup_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/cpu.go b/src/go/rpk/pkg/system/cpu.go index 37feb93fda16..bb325e02aba5 100644 --- a/src/go/rpk/pkg/system/cpu.go +++ b/src/go/rpk/pkg/system/cpu.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/filesystem/fs.go b/src/go/rpk/pkg/system/filesystem/fs.go index a45fdc7a5257..d6ed3b9af1ec 100644 --- a/src/go/rpk/pkg/system/filesystem/fs.go +++ b/src/go/rpk/pkg/system/filesystem/fs.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/filesystem/fs_darwin.go b/src/go/rpk/pkg/system/filesystem/fs_darwin.go index 60ecf6e9335c..69d19fa6359c 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_darwin.go +++ b/src/go/rpk/pkg/system/filesystem/fs_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/filesystem/fs_linux.go b/src/go/rpk/pkg/system/filesystem/fs_linux.go index 540a630a6604..88c66888e5e0 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_linux.go +++ b/src/go/rpk/pkg/system/filesystem/fs_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/filesystem/fs_test.go b/src/go/rpk/pkg/system/filesystem/fs_test.go index e5c198080fda..8802615a9ed5 100644 --- a/src/go/rpk/pkg/system/filesystem/fs_test.go +++ b/src/go/rpk/pkg/system/filesystem/fs_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/filesystem/types.go b/src/go/rpk/pkg/system/filesystem/types.go index d9fa0abd8e9d..e1bf3cabd7bd 100644 --- a/src/go/rpk/pkg/system/filesystem/types.go +++ b/src/go/rpk/pkg/system/filesystem/types.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/grub.go b/src/go/rpk/pkg/system/grub.go index 26e25d7c672c..debf70776a50 100644 --- a/src/go/rpk/pkg/system/grub.go +++ b/src/go/rpk/pkg/system/grub.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/grub_test.go b/src/go/rpk/pkg/system/grub_test.go index 9330bcbdf67e..8d46d7ef4061 100644 --- a/src/go/rpk/pkg/system/grub_test.go +++ b/src/go/rpk/pkg/system/grub_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/memory.go b/src/go/rpk/pkg/system/memory.go index 70859fa5c42a..e3d2e5645d98 100644 --- a/src/go/rpk/pkg/system/memory.go +++ b/src/go/rpk/pkg/system/memory.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/memory_darwin.go b/src/go/rpk/pkg/system/memory_darwin.go index e4936adff742..9e48de9db112 100644 --- a/src/go/rpk/pkg/system/memory_darwin.go +++ b/src/go/rpk/pkg/system/memory_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/memory_linux.go b/src/go/rpk/pkg/system/memory_linux.go index 8d716cfab17a..19a5a4e4852c 100644 --- a/src/go/rpk/pkg/system/memory_linux.go +++ b/src/go/rpk/pkg/system/memory_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/ntp.go b/src/go/rpk/pkg/system/ntp.go index 3c1a851b00a1..3f9b58a2f7d5 100644 --- a/src/go/rpk/pkg/system/ntp.go +++ b/src/go/rpk/pkg/system/ntp.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/ntp_test.go b/src/go/rpk/pkg/system/ntp_test.go index 66f8a192a9de..43e9a3f86913 100644 --- a/src/go/rpk/pkg/system/ntp_test.go +++ b/src/go/rpk/pkg/system/ntp_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/runtime_options.go b/src/go/rpk/pkg/system/runtime_options.go index 534a17d0f085..43ddd16f69f2 100644 --- a/src/go/rpk/pkg/system/runtime_options.go +++ b/src/go/rpk/pkg/system/runtime_options.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/runtime_options_test.go b/src/go/rpk/pkg/system/runtime_options_test.go index 61580213f456..a680f103b601 100644 --- a/src/go/rpk/pkg/system/runtime_options_test.go +++ b/src/go/rpk/pkg/system/runtime_options_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/systemd/client.go b/src/go/rpk/pkg/system/systemd/client.go index ae71d4cdb7f3..425e4fba9338 100644 --- a/src/go/rpk/pkg/system/systemd/client.go +++ b/src/go/rpk/pkg/system/systemd/client.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/systemd/dbus.go b/src/go/rpk/pkg/system/systemd/dbus.go index 1f6ae2d33ac9..be20d1d26443 100644 --- a/src/go/rpk/pkg/system/systemd/dbus.go +++ b/src/go/rpk/pkg/system/systemd/dbus.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/systemd/mock.go b/src/go/rpk/pkg/system/systemd/mock.go index bb1ede117827..521d59338f1f 100644 --- a/src/go/rpk/pkg/system/systemd/mock.go +++ b/src/go/rpk/pkg/system/systemd/mock.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/utils.go b/src/go/rpk/pkg/system/utils.go index d514f97fd8d6..220f989b2af7 100644 --- a/src/go/rpk/pkg/system/utils.go +++ b/src/go/rpk/pkg/system/utils.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/utils_darwin.go b/src/go/rpk/pkg/system/utils_darwin.go index adafbc6b13c3..3e43ae0ab949 100644 --- a/src/go/rpk/pkg/system/utils_darwin.go +++ b/src/go/rpk/pkg/system/utils_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/utils_linux.go b/src/go/rpk/pkg/system/utils_linux.go index 431bae88d6be..b1de66fe4acd 100644 --- a/src/go/rpk/pkg/system/utils_linux.go +++ b/src/go/rpk/pkg/system/utils_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/aggregated_tunable.go b/src/go/rpk/pkg/tuners/aggregated_tunable.go index ddd1a183b288..6d7f6d4dcaea 100644 --- a/src/go/rpk/pkg/tuners/aggregated_tunable.go +++ b/src/go/rpk/pkg/tuners/aggregated_tunable.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/aggregated_tunable_test.go b/src/go/rpk/pkg/tuners/aggregated_tunable_test.go index 0f502d2b624d..6c6dd65ed919 100644 --- a/src/go/rpk/pkg/tuners/aggregated_tunable_test.go +++ b/src/go/rpk/pkg/tuners/aggregated_tunable_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/aio.go b/src/go/rpk/pkg/tuners/aio.go index b3ecabeed7bf..74b77ab49bc0 100644 --- a/src/go/rpk/pkg/tuners/aio.go +++ b/src/go/rpk/pkg/tuners/aio.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/aio_test.go b/src/go/rpk/pkg/tuners/aio_test.go index 1415ea69a57f..11eb75b951e0 100644 --- a/src/go/rpk/pkg/tuners/aio_test.go +++ b/src/go/rpk/pkg/tuners/aio_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/check.go b/src/go/rpk/pkg/tuners/check.go index db622d8081cc..453018698b85 100644 --- a/src/go/rpk/pkg/tuners/check.go +++ b/src/go/rpk/pkg/tuners/check.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/checked_tunable.go b/src/go/rpk/pkg/tuners/checked_tunable.go index 9be60d9adbbc..07bc2c768b9a 100644 --- a/src/go/rpk/pkg/tuners/checked_tunable.go +++ b/src/go/rpk/pkg/tuners/checked_tunable.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/checked_tunable_test.go b/src/go/rpk/pkg/tuners/checked_tunable_test.go index a1f6a0e4c1c5..a7fddce33141 100644 --- a/src/go/rpk/pkg/tuners/checked_tunable_test.go +++ b/src/go/rpk/pkg/tuners/checked_tunable_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/checker.go b/src/go/rpk/pkg/tuners/checker.go index 93de8f6f2ddf..790a8963cf34 100644 --- a/src/go/rpk/pkg/tuners/checker.go +++ b/src/go/rpk/pkg/tuners/checker.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/clocksource.go b/src/go/rpk/pkg/tuners/clocksource.go index aa6b77e71e35..dcfcb0095c31 100644 --- a/src/go/rpk/pkg/tuners/clocksource.go +++ b/src/go/rpk/pkg/tuners/clocksource.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/coredump/tuner.go b/src/go/rpk/pkg/tuners/coredump/tuner.go index 72acb7016267..2a3ec80efa48 100644 --- a/src/go/rpk/pkg/tuners/coredump/tuner.go +++ b/src/go/rpk/pkg/tuners/coredump/tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/coredump/tuner_test.go b/src/go/rpk/pkg/tuners/coredump/tuner_test.go index 6d0b7654cc61..07b5f0680bf2 100644 --- a/src/go/rpk/pkg/tuners/coredump/tuner_test.go +++ b/src/go/rpk/pkg/tuners/coredump/tuner_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/cpu/tuner.go b/src/go/rpk/pkg/tuners/cpu/tuner.go index cd41f3095377..44e4a0e5afac 100644 --- a/src/go/rpk/pkg/tuners/cpu/tuner.go +++ b/src/go/rpk/pkg/tuners/cpu/tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk/block_device.go b/src/go/rpk/pkg/tuners/disk/block_device.go index 72fe91d64b8e..39d0338f0af5 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device.go +++ b/src/go/rpk/pkg/tuners/disk/block_device.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 90ac0792ddc7..190518b1db77 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_darwin.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 56693410bddf..627773eb5d50 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_linux.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 6cfcc3bfa0cd..02a78d455cf2 100644 --- a/src/go/rpk/pkg/tuners/disk/block_device_test.go +++ b/src/go/rpk/pkg/tuners/disk/block_device_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk/block_devices.go b/src/go/rpk/pkg/tuners/disk/block_devices.go index 11a79033ba12..428be4e7762a 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 775a448a92d6..190bf12f20e9 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 259d3bedcb1e..2bb5fb029eaf 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_linux.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 26f0f7c26229..e60e35f4ccb3 100644 --- a/src/go/rpk/pkg/tuners/disk/block_devices_test.go +++ b/src/go/rpk/pkg/tuners/disk/block_devices_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk/device_features.go b/src/go/rpk/pkg/tuners/disk/device_features.go index eaaa8566a251..8f79bd0bce8e 100644 --- a/src/go/rpk/pkg/tuners/disk/device_features.go +++ b/src/go/rpk/pkg/tuners/disk/device_features.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk/device_features_test.go b/src/go/rpk/pkg/tuners/disk/device_features_test.go index 95388aa55a78..e439fb00fc93 100644 --- a/src/go/rpk/pkg/tuners/disk/device_features_test.go +++ b/src/go/rpk/pkg/tuners/disk/device_features_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk_checkers.go b/src/go/rpk/pkg/tuners/disk_checkers.go index a0bc812a8168..577e90c44c0f 100644 --- a/src/go/rpk/pkg/tuners/disk_checkers.go +++ b/src/go/rpk/pkg/tuners/disk_checkers.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go b/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go index 017b674461ac..be4052e6a3eb 100644 --- a/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_nomerges_tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 e908ce065e7c..38c46c188fa9 100644 --- a/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disk_nomerges_tuner_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go b/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go index b6eb3fb8e3f4..1a35c1e996ca 100644 --- a/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_scheduler_tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 af8715712163..b3fbb4342a2b 100644 --- a/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disk_scheduler_tuner_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disk_tuner.go b/src/go/rpk/pkg/tuners/disk_tuner.go index 2fd3034ac77e..33bb525e7e57 100644 --- a/src/go/rpk/pkg/tuners/disk_tuner.go +++ b/src/go/rpk/pkg/tuners/disk_tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/disks_irq_tuner.go b/src/go/rpk/pkg/tuners/disks_irq_tuner.go index 1ffb1130c30a..ddfe5c0f7323 100644 --- a/src/go/rpk/pkg/tuners/disks_irq_tuner.go +++ b/src/go/rpk/pkg/tuners/disks_irq_tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 528798e01d0c..1aa5689886cf 100644 --- a/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go +++ b/src/go/rpk/pkg/tuners/disks_irq_tuner_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/equality_checker.go b/src/go/rpk/pkg/tuners/equality_checker.go index 879228b8bee9..94cc3da86a13 100644 --- a/src/go/rpk/pkg/tuners/equality_checker.go +++ b/src/go/rpk/pkg/tuners/equality_checker.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/equality_checker_test.go b/src/go/rpk/pkg/tuners/equality_checker_test.go index f6f19f886da4..790b257057a1 100644 --- a/src/go/rpk/pkg/tuners/equality_checker_test.go +++ b/src/go/rpk/pkg/tuners/equality_checker_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/ethtool/ethtool.go b/src/go/rpk/pkg/tuners/ethtool/ethtool.go index 7e2da7cbf7ad..a96aaed1c573 100644 --- a/src/go/rpk/pkg/tuners/ethtool/ethtool.go +++ b/src/go/rpk/pkg/tuners/ethtool/ethtool.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 8a0a32d5a92a..81ed06b6e4cb 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/backup_file.go +++ b/src/go/rpk/pkg/tuners/executors/commands/backup_file.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/commands/command.go b/src/go/rpk/pkg/tuners/executors/commands/command.go index 9611f10f825c..8e6dd41b43d3 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/command.go +++ b/src/go/rpk/pkg/tuners/executors/commands/command.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 361a37bf322e..99a64a4dd232 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go +++ b/src/go/rpk/pkg/tuners/executors/commands/ethtool_change.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/commands/execute.go b/src/go/rpk/pkg/tuners/executors/commands/execute.go index 4c7dcd76f740..ed597c4569bf 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/execute.go +++ b/src/go/rpk/pkg/tuners/executors/commands/execute.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 109f05220b00..6564fe846560 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go +++ b/src/go/rpk/pkg/tuners/executors/commands/sysctl_set.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 9318b02927fa..b1ced8585b2b 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 e158bf3ee088..f58a89a95e61 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 b7b9be389826..9507f3db5b2a 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 bce36d5e25d6..57b91a686c10 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 befa972bd1c5..8ac1404b6309 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_file.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_file.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 801f26ac4904..cabbef397e4b 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 d53987e4d53c..f6059fb3c49c 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,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/direct.go b/src/go/rpk/pkg/tuners/executors/direct.go index 1ad414e1ceac..c8bbfb8e4768 100644 --- a/src/go/rpk/pkg/tuners/executors/direct.go +++ b/src/go/rpk/pkg/tuners/executors/direct.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/executor.go b/src/go/rpk/pkg/tuners/executors/executor.go index a49165bac238..c06b9115b5c2 100644 --- a/src/go/rpk/pkg/tuners/executors/executor.go +++ b/src/go/rpk/pkg/tuners/executors/executor.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/script_rendering.go b/src/go/rpk/pkg/tuners/executors/script_rendering.go index 9a611e5de3bf..356f0a250bb5 100644 --- a/src/go/rpk/pkg/tuners/executors/script_rendering.go +++ b/src/go/rpk/pkg/tuners/executors/script_rendering.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/factory/factory_test.go b/src/go/rpk/pkg/tuners/factory/factory_test.go index cd6a9a2ffd18..a062337da28a 100644 --- a/src/go/rpk/pkg/tuners/factory/factory_test.go +++ b/src/go/rpk/pkg/tuners/factory/factory_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/file_existance_checker.go b/src/go/rpk/pkg/tuners/file_existance_checker.go index 8ad04be80aef..60e0708b9173 100644 --- a/src/go/rpk/pkg/tuners/file_existance_checker.go +++ b/src/go/rpk/pkg/tuners/file_existance_checker.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/float_checker.go b/src/go/rpk/pkg/tuners/float_checker.go index 334c6aba0884..372bdbf3aee6 100644 --- a/src/go/rpk/pkg/tuners/float_checker.go +++ b/src/go/rpk/pkg/tuners/float_checker.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/float_checker_test.go b/src/go/rpk/pkg/tuners/float_checker_test.go index 1387e320be09..2859fc538029 100644 --- a/src/go/rpk/pkg/tuners/float_checker_test.go +++ b/src/go/rpk/pkg/tuners/float_checker_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/fstrim.go b/src/go/rpk/pkg/tuners/fstrim.go index d5d43a0d6013..2a873964b57c 100644 --- a/src/go/rpk/pkg/tuners/fstrim.go +++ b/src/go/rpk/pkg/tuners/fstrim.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/fstrim_test.go b/src/go/rpk/pkg/tuners/fstrim_test.go index 25e55f112d75..9e1ec64956aa 100644 --- a/src/go/rpk/pkg/tuners/fstrim_test.go +++ b/src/go/rpk/pkg/tuners/fstrim_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner.go b/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner.go index e2ccc0ae6bbb..615f279a9992 100644 --- a/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner.go +++ b/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner_test.go b/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner_test.go index de87a4f6e2b9..9c5f3fe9b6ef 100644 --- a/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner_test.go +++ b/src/go/rpk/pkg/tuners/gcp_disk_write_cache_tuner_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/hwloc/cpuset.go b/src/go/rpk/pkg/tuners/hwloc/cpuset.go index d9d37b1b6b3b..47a611e80415 100644 --- a/src/go/rpk/pkg/tuners/hwloc/cpuset.go +++ b/src/go/rpk/pkg/tuners/hwloc/cpuset.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go b/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go index 20168dc15621..2dfc72d91c67 100644 --- a/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go +++ b/src/go/rpk/pkg/tuners/hwloc/cpuset_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/hwloc/hwloc.go b/src/go/rpk/pkg/tuners/hwloc/hwloc.go index ee7530c01fbb..adecf8e91111 100644 --- a/src/go/rpk/pkg/tuners/hwloc/hwloc.go +++ b/src/go/rpk/pkg/tuners/hwloc/hwloc.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go b/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go index 075c4f0d01be..b8042beeb067 100644 --- a/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go +++ b/src/go/rpk/pkg/tuners/hwloc/hwloc_cmd.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/int_checker.go b/src/go/rpk/pkg/tuners/int_checker.go index 89407773e1c2..f5a03d496a87 100644 --- a/src/go/rpk/pkg/tuners/int_checker.go +++ b/src/go/rpk/pkg/tuners/int_checker.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/int_checker_test.go b/src/go/rpk/pkg/tuners/int_checker_test.go index 9e9b026ce56d..a6467ce7a964 100644 --- a/src/go/rpk/pkg/tuners/int_checker_test.go +++ b/src/go/rpk/pkg/tuners/int_checker_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/iotune.go b/src/go/rpk/pkg/tuners/iotune.go index d1e2ea2cc13a..ed04d6c00d9b 100644 --- a/src/go/rpk/pkg/tuners/iotune.go +++ b/src/go/rpk/pkg/tuners/iotune.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/iotune/data.go b/src/go/rpk/pkg/tuners/iotune/data.go index e3cf901c9792..3743657cae64 100644 --- a/src/go/rpk/pkg/tuners/iotune/data.go +++ b/src/go/rpk/pkg/tuners/iotune/data.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/iotune/data_test.go b/src/go/rpk/pkg/tuners/iotune/data_test.go index 8a9e5edc68fd..a88d16fdc5da 100644 --- a/src/go/rpk/pkg/tuners/iotune/data_test.go +++ b/src/go/rpk/pkg/tuners/iotune/data_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/iotune/io_tune.go b/src/go/rpk/pkg/tuners/iotune/io_tune.go index 7fb460f2dfff..fce1398ed87f 100644 --- a/src/go/rpk/pkg/tuners/iotune/io_tune.go +++ b/src/go/rpk/pkg/tuners/iotune/io_tune.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/irq/balance_service.go b/src/go/rpk/pkg/tuners/irq/balance_service.go index 60e1be9ae676..12b3023fd35e 100644 --- a/src/go/rpk/pkg/tuners/irq/balance_service.go +++ b/src/go/rpk/pkg/tuners/irq/balance_service.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 a16061bf2add..8b859f35a05a 100644 --- a/src/go/rpk/pkg/tuners/irq/balance_service_test.go +++ b/src/go/rpk/pkg/tuners/irq/balance_service_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/irq/cpu_masks.go b/src/go/rpk/pkg/tuners/irq/cpu_masks.go index 19ed20bade32..ac1fd290b80f 100644 --- a/src/go/rpk/pkg/tuners/irq/cpu_masks.go +++ b/src/go/rpk/pkg/tuners/irq/cpu_masks.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 4cb4f5b507e0..57d853104114 100644 --- a/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go +++ b/src/go/rpk/pkg/tuners/irq/cpu_masks_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/irq/device_info.go b/src/go/rpk/pkg/tuners/irq/device_info.go index 962eb9164f5e..3c94aaae251d 100644 --- a/src/go/rpk/pkg/tuners/irq/device_info.go +++ b/src/go/rpk/pkg/tuners/irq/device_info.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 3fc07eb26e5a..74cb848bdbc8 100644 --- a/src/go/rpk/pkg/tuners/irq/device_info_test.go +++ b/src/go/rpk/pkg/tuners/irq/device_info_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 e2f4c2295133..0c0e1d5e2bf8 100644 --- a/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go +++ b/src/go/rpk/pkg/tuners/irq/irq_tuner_mode.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/irq/proc_file.go b/src/go/rpk/pkg/tuners/irq/proc_file.go index e4cd9cb889ac..d0f61859415d 100644 --- a/src/go/rpk/pkg/tuners/irq/proc_file.go +++ b/src/go/rpk/pkg/tuners/irq/proc_file.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md 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 1dd0cdb35323..d36570355c11 100644 --- a/src/go/rpk/pkg/tuners/irq/proc_file_test.go +++ b/src/go/rpk/pkg/tuners/irq/proc_file_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/irq/utils.go b/src/go/rpk/pkg/tuners/irq/utils.go index 48b1f3ef1c7f..752d33d54b12 100644 --- a/src/go/rpk/pkg/tuners/irq/utils.go +++ b/src/go/rpk/pkg/tuners/irq/utils.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/kernel_version.go b/src/go/rpk/pkg/tuners/kernel_version.go index ddee077245f8..b9220acf616b 100644 --- a/src/go/rpk/pkg/tuners/kernel_version.go +++ b/src/go/rpk/pkg/tuners/kernel_version.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/kernel_version_darwin.go b/src/go/rpk/pkg/tuners/kernel_version_darwin.go index ec9e82083d7e..f4dbac0bbc54 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_darwin.go +++ b/src/go/rpk/pkg/tuners/kernel_version_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/kernel_version_linux.go b/src/go/rpk/pkg/tuners/kernel_version_linux.go index 6fc8d593b9c1..474587b51b9b 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_linux.go +++ b/src/go/rpk/pkg/tuners/kernel_version_linux.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/kernel_version_test.go b/src/go/rpk/pkg/tuners/kernel_version_test.go index 8c332a0a3bd4..b3f1c5af121f 100644 --- a/src/go/rpk/pkg/tuners/kernel_version_test.go +++ b/src/go/rpk/pkg/tuners/kernel_version_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/net_checkers.go b/src/go/rpk/pkg/tuners/net_checkers.go index bd238ebcd732..3555161d1142 100644 --- a/src/go/rpk/pkg/tuners/net_checkers.go +++ b/src/go/rpk/pkg/tuners/net_checkers.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/net_tuners.go b/src/go/rpk/pkg/tuners/net_tuners.go index e9bfc226bf5a..f3ee0dea8778 100644 --- a/src/go/rpk/pkg/tuners/net_tuners.go +++ b/src/go/rpk/pkg/tuners/net_tuners.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/net_tuners_test.go b/src/go/rpk/pkg/tuners/net_tuners_test.go index b08e5abbbaf4..c84bbf59b711 100644 --- a/src/go/rpk/pkg/tuners/net_tuners_test.go +++ b/src/go/rpk/pkg/tuners/net_tuners_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/network/const.go b/src/go/rpk/pkg/tuners/network/const.go index 8c5a53bf43ab..88cf4a6cdada 100644 --- a/src/go/rpk/pkg/tuners/network/const.go +++ b/src/go/rpk/pkg/tuners/network/const.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/network/nic.go b/src/go/rpk/pkg/tuners/network/nic.go index be12a6e4d2ca..d73c66df8611 100644 --- a/src/go/rpk/pkg/tuners/network/nic.go +++ b/src/go/rpk/pkg/tuners/network/nic.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/network/nic_test.go b/src/go/rpk/pkg/tuners/network/nic_test.go index 5a50c7f11ce4..1a935d56b82f 100644 --- a/src/go/rpk/pkg/tuners/network/nic_test.go +++ b/src/go/rpk/pkg/tuners/network/nic_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/network/nics.go b/src/go/rpk/pkg/tuners/network/nics.go index f6e78c56934c..faa3078bab50 100644 --- a/src/go/rpk/pkg/tuners/network/nics.go +++ b/src/go/rpk/pkg/tuners/network/nics.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/redpanda_checkers.go b/src/go/rpk/pkg/tuners/redpanda_checkers.go index 53706fd2282e..ca937430fd42 100644 --- a/src/go/rpk/pkg/tuners/redpanda_checkers.go +++ b/src/go/rpk/pkg/tuners/redpanda_checkers.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/redpanda_checkers_test.go b/src/go/rpk/pkg/tuners/redpanda_checkers_test.go index fa07d8ca749d..71943d689cec 100644 --- a/src/go/rpk/pkg/tuners/redpanda_checkers_test.go +++ b/src/go/rpk/pkg/tuners/redpanda_checkers_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/swappiness.go b/src/go/rpk/pkg/tuners/swappiness.go index 098bf32c346c..32ada267de5e 100644 --- a/src/go/rpk/pkg/tuners/swappiness.go +++ b/src/go/rpk/pkg/tuners/swappiness.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/swappiness_test.go b/src/go/rpk/pkg/tuners/swappiness_test.go index 3976f316d1c3..c1ce7ec3504b 100644 --- a/src/go/rpk/pkg/tuners/swappiness_test.go +++ b/src/go/rpk/pkg/tuners/swappiness_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/thp.go b/src/go/rpk/pkg/tuners/thp.go index 7893b96553a4..c6c780788638 100644 --- a/src/go/rpk/pkg/tuners/thp.go +++ b/src/go/rpk/pkg/tuners/thp.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/thp_test.go b/src/go/rpk/pkg/tuners/thp_test.go index 8dbadc7b564b..a772956e6707 100644 --- a/src/go/rpk/pkg/tuners/thp_test.go +++ b/src/go/rpk/pkg/tuners/thp_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/tunable.go b/src/go/rpk/pkg/tuners/tunable.go index 807a86d9090a..12fb20d7312b 100644 --- a/src/go/rpk/pkg/tuners/tunable.go +++ b/src/go/rpk/pkg/tuners/tunable.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/tune_result.go b/src/go/rpk/pkg/tuners/tune_result.go index f3e4b480cfad..7f8f782da598 100644 --- a/src/go/rpk/pkg/tuners/tune_result.go +++ b/src/go/rpk/pkg/tuners/tune_result.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/tune_result_test.go b/src/go/rpk/pkg/tuners/tune_result_test.go index f9e46c7089ca..d7d276ab81b9 100644 --- a/src/go/rpk/pkg/tuners/tune_result_test.go +++ b/src/go/rpk/pkg/tuners/tune_result_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/chained_error.go b/src/go/rpk/pkg/utils/chained_error.go index c5fc39bdc30c..48afc3ea2617 100644 --- a/src/go/rpk/pkg/utils/chained_error.go +++ b/src/go/rpk/pkg/utils/chained_error.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/collect.go b/src/go/rpk/pkg/utils/collect.go index f3714cf77037..d0479d02199b 100644 --- a/src/go/rpk/pkg/utils/collect.go +++ b/src/go/rpk/pkg/utils/collect.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/files.go b/src/go/rpk/pkg/utils/files.go index 63f2da281ff3..b5fc9ff90dac 100644 --- a/src/go/rpk/pkg/utils/files.go +++ b/src/go/rpk/pkg/utils/files.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/files_test.go b/src/go/rpk/pkg/utils/files_test.go index 93a4ce080ed2..5d609bbe5016 100644 --- a/src/go/rpk/pkg/utils/files_test.go +++ b/src/go/rpk/pkg/utils/files_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/os.go b/src/go/rpk/pkg/utils/os.go index 1a9b5790e669..a1ec8999885a 100644 --- a/src/go/rpk/pkg/utils/os.go +++ b/src/go/rpk/pkg/utils/os.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/strings.go b/src/go/rpk/pkg/utils/strings.go index 434be504a19a..58a4a51135bf 100644 --- a/src/go/rpk/pkg/utils/strings.go +++ b/src/go/rpk/pkg/utils/strings.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/utils/strings_test.go b/src/go/rpk/pkg/utils/strings_test.go index ce4998c9708a..910a126e951d 100644 --- a/src/go/rpk/pkg/utils/strings_test.go +++ b/src/go/rpk/pkg/utils/strings_test.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/yaml/yaml.go b/src/go/rpk/pkg/yaml/yaml.go index f21ad5ddc741..d631719153df 100644 --- a/src/go/rpk/pkg/yaml/yaml.go +++ b/src/go/rpk/pkg/yaml/yaml.go @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/js/build.sh b/src/js/build.sh index 897a0574229f..5b901f31f3d1 100755 --- a/src/js/build.sh +++ b/src/js/build.sh @@ -1,5 +1,5 @@ #!/bin/bash -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/js/generate-entries.sh b/src/js/generate-entries.sh index 7a4a011995e4..ac93d5af8128 100755 --- a/src/js/generate-entries.sh +++ b/src/js/generate-entries.sh @@ -1,5 +1,5 @@ #!/usr/bin/env bash -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Licensed as a Redpanda Enterprise file under the Redpanda Community # License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/domain/Handle.ts b/src/js/modules/domain/Handle.ts index 6cfa2f9f25c7..359ea67bb9a4 100644 --- a/src/js/modules/domain/Handle.ts +++ b/src/js/modules/domain/Handle.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/hashing/crc32.ts b/src/js/modules/hashing/crc32.ts index ed5939c3babf..19ef4f8387a8 100644 --- a/src/js/modules/hashing/crc32.ts +++ b/src/js/modules/hashing/crc32.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/hashing/xxhash.ts b/src/js/modules/hashing/xxhash.ts index 3cde467e0f9c..b3c7d390cfd0 100644 --- a/src/js/modules/hashing/xxhash.ts +++ b/src/js/modules/hashing/xxhash.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/public/Coprocessor.ts b/src/js/modules/public/Coprocessor.ts index d29e008d608c..66a4a3454787 100644 --- a/src/js/modules/public/Coprocessor.ts +++ b/src/js/modules/public/Coprocessor.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/public/SimpleTransform.ts b/src/js/modules/public/SimpleTransform.ts index 0c6b803b7a80..bdc24958935a 100644 --- a/src/js/modules/public/SimpleTransform.ts +++ b/src/js/modules/public/SimpleTransform.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/public/Utils.ts b/src/js/modules/public/Utils.ts index 48f585f614c9..3be79f7ba209 100644 --- a/src/js/modules/public/Utils.ts +++ b/src/js/modules/public/Utils.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/public/index.ts b/src/js/modules/public/index.ts index 8c3417c7271e..772d7641b30c 100644 --- a/src/js/modules/public/index.ts +++ b/src/js/modules/public/index.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/rpc/errors.ts b/src/js/modules/rpc/errors.ts index 0b6cc1b68534..be3f28cd9492 100644 --- a/src/js/modules/rpc/errors.ts +++ b/src/js/modules/rpc/errors.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/rpc/parser.ts b/src/js/modules/rpc/parser.ts index 812fa17a83d6..b1c38922e02b 100644 --- a/src/js/modules/rpc/parser.ts +++ b/src/js/modules/rpc/parser.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/rpc/server.ts b/src/js/modules/rpc/server.ts index 3bc3fac28ef1..2bb2748b2e4b 100644 --- a/src/js/modules/rpc/server.ts +++ b/src/js/modules/rpc/server.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/rpc/service.ts b/src/js/modules/rpc/service.ts index 35cc6bb3efae..6d83373dd5f2 100644 --- a/src/js/modules/rpc/service.ts +++ b/src/js/modules/rpc/service.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/rpc/types.ts b/src/js/modules/rpc/types.ts index 0b2da3d75d91..be1f0c0ec827 100644 --- a/src/js/modules/rpc/types.ts +++ b/src/js/modules/rpc/types.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/supervisors/HandleTable.ts b/src/js/modules/supervisors/HandleTable.ts index b142a0432639..d51f399af9b9 100644 --- a/src/js/modules/supervisors/HandleTable.ts +++ b/src/js/modules/supervisors/HandleTable.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/supervisors/Repository.ts b/src/js/modules/supervisors/Repository.ts index 9a6d5c69a889..0ee67ae7be52 100644 --- a/src/js/modules/supervisors/Repository.ts +++ b/src/js/modules/supervisors/Repository.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/utilities/Checksum.ts b/src/js/modules/utilities/Checksum.ts index 7a0ed03c2f53..3fe94ac493fb 100644 --- a/src/js/modules/utilities/Checksum.ts +++ b/src/js/modules/utilities/Checksum.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/utilities/IOBuf.ts b/src/js/modules/utilities/IOBuf.ts index fcbec59768e3..29565085027b 100644 --- a/src/js/modules/utilities/IOBuf.ts +++ b/src/js/modules/utilities/IOBuf.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/utilities/Logging.ts b/src/js/modules/utilities/Logging.ts index d5e2d71ab54a..a6d68f814cb2 100644 --- a/src/js/modules/utilities/Logging.ts +++ b/src/js/modules/utilities/Logging.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/modules/utilities/Map.ts b/src/js/modules/utilities/Map.ts index cf07ec20e7c8..375b7e200260 100644 --- a/src/js/modules/utilities/Map.ts +++ b/src/js/modules/utilities/Map.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/publish-wasm-dependecy.js b/src/js/publish-wasm-dependecy.js index d2fa28347f0e..c19eb2f44de0 100755 --- a/src/js/publish-wasm-dependecy.js +++ b/src/js/publish-wasm-dependecy.js @@ -1,6 +1,6 @@ #!/usr/bin/env node /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/rpc/server.test.ts b/src/js/test/rpc/server.test.ts index bad2001845de..3dd2d2fddf9b 100644 --- a/src/js/test/rpc/server.test.ts +++ b/src/js/test/rpc/server.test.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/supervisors/Repository.test.ts b/src/js/test/supervisors/Repository.test.ts index 25c277a5bc63..7cee00fed7e9 100644 --- a/src/js/test/supervisors/Repository.test.ts +++ b/src/js/test/supervisors/Repository.test.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/testUtilities.ts b/src/js/test/testUtilities.ts index 886633416412..e3a950d8b42e 100644 --- a/src/js/test/testUtilities.ts +++ b/src/js/test/testUtilities.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/utilities/Checksum.test.ts b/src/js/test/utilities/Checksum.test.ts index 1cd923f347e1..83c1019b7c23 100644 --- a/src/js/test/utilities/Checksum.test.ts +++ b/src/js/test/utilities/Checksum.test.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/utilities/CoprocessorTest.ts b/src/js/test/utilities/CoprocessorTest.ts index a62f5af54c39..f6109399b7e5 100644 --- a/src/js/test/utilities/CoprocessorTest.ts +++ b/src/js/test/utilities/CoprocessorTest.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/js/test/utilities/iobuf.test.ts b/src/js/test/utilities/iobuf.test.ts index eb076a62ba30..0acd3e412059 100644 --- a/src/js/test/utilities/iobuf.test.ts +++ b/src/js/test/utilities/iobuf.test.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/bytes/bytes.cc b/src/v/bytes/bytes.cc index 13753c2a34bd..d5b52038c1d5 100644 --- a/src/v/bytes/bytes.cc +++ b/src/v/bytes/bytes.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/bytes/bytes.h b/src/v/bytes/bytes.h index c3ed3e8eed2f..e0c258031df8 100644 --- a/src/v/bytes/bytes.h +++ b/src/v/bytes/bytes.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/io_allocation_size.h b/src/v/bytes/details/io_allocation_size.h index 3752dcb70bc8..e973554ffa71 100644 --- a/src/v/bytes/details/io_allocation_size.h +++ b/src/v/bytes/details/io_allocation_size.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/io_byte_iterator.h b/src/v/bytes/details/io_byte_iterator.h index fe414457f9a7..b5561b668717 100644 --- a/src/v/bytes/details/io_byte_iterator.h +++ b/src/v/bytes/details/io_byte_iterator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/io_fragment.h b/src/v/bytes/details/io_fragment.h index bd26bb52a18c..5c42d9090cbc 100644 --- a/src/v/bytes/details/io_fragment.h +++ b/src/v/bytes/details/io_fragment.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/io_iterator_consumer.h b/src/v/bytes/details/io_iterator_consumer.h index 4af1f786ee8b..ddc33023a691 100644 --- a/src/v/bytes/details/io_iterator_consumer.h +++ b/src/v/bytes/details/io_iterator_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/io_placeholder.h b/src/v/bytes/details/io_placeholder.h index 215b9b40ae21..ce13e26b315c 100644 --- a/src/v/bytes/details/io_placeholder.h +++ b/src/v/bytes/details/io_placeholder.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/details/out_of_range.h b/src/v/bytes/details/out_of_range.h index 3e0e2f80fa08..1a29f6ec293b 100644 --- a/src/v/bytes/details/out_of_range.h +++ b/src/v/bytes/details/out_of_range.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/iobuf.cc b/src/v/bytes/iobuf.cc index b9c153e08cc7..5a9db31c30ec 100644 --- a/src/v/bytes/iobuf.cc +++ b/src/v/bytes/iobuf.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/bytes/iobuf.h b/src/v/bytes/iobuf.h index fffe00d5b6c3..d042e8d06289 100644 --- a/src/v/bytes/iobuf.h +++ b/src/v/bytes/iobuf.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/iobuf_istreambuf.h b/src/v/bytes/iobuf_istreambuf.h index d7c04ff58c17..4259cff2ef7b 100644 --- a/src/v/bytes/iobuf_istreambuf.h +++ b/src/v/bytes/iobuf_istreambuf.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/iobuf_ostreambuf.h b/src/v/bytes/iobuf_ostreambuf.h index 7a530dd8de49..eb2d50dd7c29 100644 --- a/src/v/bytes/iobuf_ostreambuf.h +++ b/src/v/bytes/iobuf_ostreambuf.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/iobuf_parser.h b/src/v/bytes/iobuf_parser.h index 2bce878fd49a..7d453cf95a19 100644 --- a/src/v/bytes/iobuf_parser.h +++ b/src/v/bytes/iobuf_parser.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/tests/bytes_tests.cc b/src/v/bytes/tests/bytes_tests.cc index 60289280c277..3cca5622a934 100644 --- a/src/v/bytes/tests/bytes_tests.cc +++ b/src/v/bytes/tests/bytes_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/bytes/tests/iobuf_tests.cc b/src/v/bytes/tests/iobuf_tests.cc index e7c43409dfde..d97f704fb64b 100644 --- a/src/v/bytes/tests/iobuf_tests.cc +++ b/src/v/bytes/tests/iobuf_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/bytes/tests/iobuf_utils_tests.cc b/src/v/bytes/tests/iobuf_utils_tests.cc index 99d1fadf5197..f2e698c2a397 100644 --- a/src/v/bytes/tests/iobuf_utils_tests.cc +++ b/src/v/bytes/tests/iobuf_utils_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/bytes/tests/utils.h b/src/v/bytes/tests/utils.h index 5d128a86ae18..e8004e14a485 100644 --- a/src/v/bytes/tests/utils.h +++ b/src/v/bytes/tests/utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/bytes/utils.h b/src/v/bytes/utils.h index 2eaaf49de4b8..cbadb4787029 100644 --- a/src/v/bytes/utils.h +++ b/src/v/bytes/utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/cluster_utils.cc b/src/v/cluster/cluster_utils.cc index 7c286e43f2fc..a1f46201ce4c 100644 --- a/src/v/cluster/cluster_utils.cc +++ b/src/v/cluster/cluster_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/cluster_utils.h b/src/v/cluster/cluster_utils.h index 72bfc142386b..911422771935 100644 --- a/src/v/cluster/cluster_utils.h +++ b/src/v/cluster/cluster_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/commands.h b/src/v/cluster/commands.h index 8f6f445260ad..ab11fac571d6 100644 --- a/src/v/cluster/commands.h +++ b/src/v/cluster/commands.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/controller.cc b/src/v/cluster/controller.cc index 338150663562..aaa103b4a68f 100644 --- a/src/v/cluster/controller.cc +++ b/src/v/cluster/controller.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/controller.h b/src/v/cluster/controller.h index 8677ebbe74e2..035d8faf4c5a 100644 --- a/src/v/cluster/controller.h +++ b/src/v/cluster/controller.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/controller_api.cc b/src/v/cluster/controller_api.cc index dff9c9f2cd91..0d7d839802d5 100644 --- a/src/v/cluster/controller_api.cc +++ b/src/v/cluster/controller_api.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/controller_api.h b/src/v/cluster/controller_api.h index 207714bea2e5..21a90f106e2a 100644 --- a/src/v/cluster/controller_api.h +++ b/src/v/cluster/controller_api.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/controller_backend.cc b/src/v/cluster/controller_backend.cc index bccd5adf8fc7..5c32decc1f11 100644 --- a/src/v/cluster/controller_backend.cc +++ b/src/v/cluster/controller_backend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/controller_backend.h b/src/v/cluster/controller_backend.h index 27af0f6bc66a..42f8ab7a8ea0 100644 --- a/src/v/cluster/controller_backend.h +++ b/src/v/cluster/controller_backend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/controller_stm.h b/src/v/cluster/controller_stm.h index 2ec6e99f609d..c070b86089a1 100644 --- a/src/v/cluster/controller_stm.h +++ b/src/v/cluster/controller_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/errc.h b/src/v/cluster/errc.h index a1dad4917acf..426b60535477 100644 --- a/src/v/cluster/errc.h +++ b/src/v/cluster/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/fwd.h b/src/v/cluster/fwd.h index fceec21de49d..105e9ea267fc 100644 --- a/src/v/cluster/fwd.h +++ b/src/v/cluster/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_backend.cc b/src/v/cluster/health_monitor_backend.cc index ee3e96ee6678..f3caee76403f 100644 --- a/src/v/cluster/health_monitor_backend.cc +++ b/src/v/cluster/health_monitor_backend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_backend.h b/src/v/cluster/health_monitor_backend.h index 7b75f7c1d103..0e6ec1da24e1 100644 --- a/src/v/cluster/health_monitor_backend.h +++ b/src/v/cluster/health_monitor_backend.h @@ -1,6 +1,6 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_frontend.cc b/src/v/cluster/health_monitor_frontend.cc index 1f4cae5ab2fc..099c1391b74b 100644 --- a/src/v/cluster/health_monitor_frontend.cc +++ b/src/v/cluster/health_monitor_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_frontend.h b/src/v/cluster/health_monitor_frontend.h index 3d8171d4a0e3..e7be35613cfe 100644 --- a/src/v/cluster/health_monitor_frontend.h +++ b/src/v/cluster/health_monitor_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_types.cc b/src/v/cluster/health_monitor_types.cc index e1446ea436ee..bc7bceb06805 100644 --- a/src/v/cluster/health_monitor_types.cc +++ b/src/v/cluster/health_monitor_types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_monitor_types.h b/src/v/cluster/health_monitor_types.h index b742963fe7a8..07476fb04928 100644 --- a/src/v/cluster/health_monitor_types.h +++ b/src/v/cluster/health_monitor_types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator.cc b/src/v/cluster/id_allocator.cc index 8e6e6de9aed8..0dc40202508b 100644 --- a/src/v/cluster/id_allocator.cc +++ b/src/v/cluster/id_allocator.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator.h b/src/v/cluster/id_allocator.h index 0cd92dbdbe73..4b46b844f17f 100644 --- a/src/v/cluster/id_allocator.h +++ b/src/v/cluster/id_allocator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator_frontend.cc b/src/v/cluster/id_allocator_frontend.cc index b88c4020cd99..fe7c46dd33dc 100644 --- a/src/v/cluster/id_allocator_frontend.cc +++ b/src/v/cluster/id_allocator_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator_frontend.h b/src/v/cluster/id_allocator_frontend.h index f9c3ec06178c..689e5140e9ec 100644 --- a/src/v/cluster/id_allocator_frontend.h +++ b/src/v/cluster/id_allocator_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator_stm.cc b/src/v/cluster/id_allocator_stm.cc index be856eb2022c..2a58376ac1af 100644 --- a/src/v/cluster/id_allocator_stm.cc +++ b/src/v/cluster/id_allocator_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/id_allocator_stm.h b/src/v/cluster/id_allocator_stm.h index c4501279020c..04192fb9b7cd 100644 --- a/src/v/cluster/id_allocator_stm.h +++ b/src/v/cluster/id_allocator_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/logger.cc b/src/v/cluster/logger.cc index fea3515b3d7e..509c7a2c0730 100644 --- a/src/v/cluster/logger.cc +++ b/src/v/cluster/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/logger.h b/src/v/cluster/logger.h index d69338a4949e..1ea6c1aa2ec7 100644 --- a/src/v/cluster/logger.h +++ b/src/v/cluster/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/members_frontend.cc b/src/v/cluster/members_frontend.cc index 6236caa921b3..4656ad342684 100644 --- a/src/v/cluster/members_frontend.cc +++ b/src/v/cluster/members_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/members_frontend.h b/src/v/cluster/members_frontend.h index c7c62188d912..fad276ca7b2e 100644 --- a/src/v/cluster/members_frontend.h +++ b/src/v/cluster/members_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/members_manager.cc b/src/v/cluster/members_manager.cc index b8ff6487c038..5d91e09e3096 100644 --- a/src/v/cluster/members_manager.cc +++ b/src/v/cluster/members_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/members_manager.h b/src/v/cluster/members_manager.h index 5c712ebfb68b..8f0b458fce71 100644 --- a/src/v/cluster/members_manager.h +++ b/src/v/cluster/members_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/members_table.cc b/src/v/cluster/members_table.cc index d6bd634ad89f..b7f53e7fcba0 100644 --- a/src/v/cluster/members_table.cc +++ b/src/v/cluster/members_table.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/members_table.h b/src/v/cluster/members_table.h index 53c167dba773..57de0506afac 100644 --- a/src/v/cluster/members_table.h +++ b/src/v/cluster/members_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_cache.cc b/src/v/cluster/metadata_cache.cc index 883ed1378237..b7faefb7f23d 100644 --- a/src/v/cluster/metadata_cache.cc +++ b/src/v/cluster/metadata_cache.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_cache.h b/src/v/cluster/metadata_cache.h index e9909bbe3c06..fcb7e92514f0 100644 --- a/src/v/cluster/metadata_cache.h +++ b/src/v/cluster/metadata_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_handler.cc b/src/v/cluster/metadata_dissemination_handler.cc index 024281079eb2..6c16dc8c7eaf 100644 --- a/src/v/cluster/metadata_dissemination_handler.cc +++ b/src/v/cluster/metadata_dissemination_handler.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_handler.h b/src/v/cluster/metadata_dissemination_handler.h index e70a4e52a463..714c7b20ea1c 100644 --- a/src/v/cluster/metadata_dissemination_handler.h +++ b/src/v/cluster/metadata_dissemination_handler.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_service.cc b/src/v/cluster/metadata_dissemination_service.cc index e424eb73acd2..0abe7a72878a 100644 --- a/src/v/cluster/metadata_dissemination_service.cc +++ b/src/v/cluster/metadata_dissemination_service.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_service.h b/src/v/cluster/metadata_dissemination_service.h index a08a4b423377..a7e315f88944 100644 --- a/src/v/cluster/metadata_dissemination_service.h +++ b/src/v/cluster/metadata_dissemination_service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_types.h b/src/v/cluster/metadata_dissemination_types.h index 4e01b8b053ea..e3aa11fecbb0 100644 --- a/src/v/cluster/metadata_dissemination_types.h +++ b/src/v/cluster/metadata_dissemination_types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_utils.cc b/src/v/cluster/metadata_dissemination_utils.cc index ad0b4817e2c0..2ad16d991ede 100644 --- a/src/v/cluster/metadata_dissemination_utils.cc +++ b/src/v/cluster/metadata_dissemination_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/metadata_dissemination_utils.h b/src/v/cluster/metadata_dissemination_utils.h index bb7ab425f9d8..d88db4861112 100644 --- a/src/v/cluster/metadata_dissemination_utils.h +++ b/src/v/cluster/metadata_dissemination_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metrics_reporter.h b/src/v/cluster/metrics_reporter.h index e07d31b35dea..562c59c621b9 100644 --- a/src/v/cluster/metrics_reporter.h +++ b/src/v/cluster/metrics_reporter.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/notification_latch.cc b/src/v/cluster/notification_latch.cc index 8b3e6fb8dc1c..a255f10f4529 100644 --- a/src/v/cluster/notification_latch.cc +++ b/src/v/cluster/notification_latch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/notification_latch.h b/src/v/cluster/notification_latch.h index 1932fc8c0ae0..0cf8ae585eec 100644 --- a/src/v/cluster/notification_latch.h +++ b/src/v/cluster/notification_latch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/ntp_callbacks.h b/src/v/cluster/ntp_callbacks.h index 2435bb6dde85..223ba2a8b172 100644 --- a/src/v/cluster/ntp_callbacks.h +++ b/src/v/cluster/ntp_callbacks.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/partition.cc b/src/v/cluster/partition.cc index cbc19f5df6bf..e7c5948cf14c 100644 --- a/src/v/cluster/partition.cc +++ b/src/v/cluster/partition.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/partition.h b/src/v/cluster/partition.h index df4f2a1592c6..06ed86fe516e 100644 --- a/src/v/cluster/partition.h +++ b/src/v/cluster/partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_leaders_table.cc b/src/v/cluster/partition_leaders_table.cc index fc022e3276c5..5951844ecc7a 100644 --- a/src/v/cluster/partition_leaders_table.cc +++ b/src/v/cluster/partition_leaders_table.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_leaders_table.h b/src/v/cluster/partition_leaders_table.h index 85db32261824..bd664032a287 100644 --- a/src/v/cluster/partition_leaders_table.h +++ b/src/v/cluster/partition_leaders_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_manager.cc b/src/v/cluster/partition_manager.cc index 16dc50eb3f8a..01d482cc868e 100644 --- a/src/v/cluster/partition_manager.cc +++ b/src/v/cluster/partition_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_manager.h b/src/v/cluster/partition_manager.h index a6fda3093783..fa66f5ea31a0 100644 --- a/src/v/cluster/partition_manager.h +++ b/src/v/cluster/partition_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_probe.cc b/src/v/cluster/partition_probe.cc index 03b80d4eb9de..45f9b94f2202 100644 --- a/src/v/cluster/partition_probe.cc +++ b/src/v/cluster/partition_probe.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/partition_probe.h b/src/v/cluster/partition_probe.h index c72f613cbc5f..8f4c316700d0 100644 --- a/src/v/cluster/partition_probe.h +++ b/src/v/cluster/partition_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/persisted_stm.cc b/src/v/cluster/persisted_stm.cc index 9a5e410d706e..66c7e5b802b0 100644 --- a/src/v/cluster/persisted_stm.cc +++ b/src/v/cluster/persisted_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/persisted_stm.h b/src/v/cluster/persisted_stm.h index a5287250a9b8..e3d3aacdb170 100644 --- a/src/v/cluster/persisted_stm.h +++ b/src/v/cluster/persisted_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/raft0_utils.h b/src/v/cluster/raft0_utils.h index 795d2bc666ba..72be1dceacde 100644 --- a/src/v/cluster/raft0_utils.h +++ b/src/v/cluster/raft0_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/rm_group_proxy.h b/src/v/cluster/rm_group_proxy.h index a6c5092075f5..045d750a98a0 100644 --- a/src/v/cluster/rm_group_proxy.h +++ b/src/v/cluster/rm_group_proxy.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/rm_partition_frontend.cc b/src/v/cluster/rm_partition_frontend.cc index 37fbc3450fb1..51f4f9f32867 100644 --- a/src/v/cluster/rm_partition_frontend.cc +++ b/src/v/cluster/rm_partition_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/rm_partition_frontend.h b/src/v/cluster/rm_partition_frontend.h index f272749c7d35..6cf893688947 100644 --- a/src/v/cluster/rm_partition_frontend.h +++ b/src/v/cluster/rm_partition_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/rm_stm.cc b/src/v/cluster/rm_stm.cc index 8a11bc246728..363664c9df07 100644 --- a/src/v/cluster/rm_stm.cc +++ b/src/v/cluster/rm_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/rm_stm.h b/src/v/cluster/rm_stm.h index 2225861327da..84cb24fb3320 100644 --- a/src/v/cluster/rm_stm.h +++ b/src/v/cluster/rm_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_node.cc b/src/v/cluster/scheduling/allocation_node.cc index abd75ccc5bdf..05017a0227f1 100644 --- a/src/v/cluster/scheduling/allocation_node.cc +++ b/src/v/cluster/scheduling/allocation_node.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_node.h b/src/v/cluster/scheduling/allocation_node.h index 7f336bc9b81e..d24273828d5c 100644 --- a/src/v/cluster/scheduling/allocation_node.h +++ b/src/v/cluster/scheduling/allocation_node.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_state.cc b/src/v/cluster/scheduling/allocation_state.cc index 923948512ed8..3acf988c3068 100644 --- a/src/v/cluster/scheduling/allocation_state.cc +++ b/src/v/cluster/scheduling/allocation_state.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_state.h b/src/v/cluster/scheduling/allocation_state.h index d26a4e2c7140..f10cd8813dc0 100644 --- a/src/v/cluster/scheduling/allocation_state.h +++ b/src/v/cluster/scheduling/allocation_state.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_strategy.cc b/src/v/cluster/scheduling/allocation_strategy.cc index ce56d26780f7..1da1898ce524 100644 --- a/src/v/cluster/scheduling/allocation_strategy.cc +++ b/src/v/cluster/scheduling/allocation_strategy.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/allocation_strategy.h b/src/v/cluster/scheduling/allocation_strategy.h index ddb6cb7d9690..9ac33d1f88e2 100644 --- a/src/v/cluster/scheduling/allocation_strategy.h +++ b/src/v/cluster/scheduling/allocation_strategy.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/constraints.cc b/src/v/cluster/scheduling/constraints.cc index a1a45be437da..a429953ad7f2 100644 --- a/src/v/cluster/scheduling/constraints.cc +++ b/src/v/cluster/scheduling/constraints.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/constraints.h b/src/v/cluster/scheduling/constraints.h index 475ade92d759..18eacd2ff3f7 100644 --- a/src/v/cluster/scheduling/constraints.h +++ b/src/v/cluster/scheduling/constraints.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer.cc b/src/v/cluster/scheduling/leader_balancer.cc index c9f4f0f3c7c1..33a2e7938adf 100644 --- a/src/v/cluster/scheduling/leader_balancer.cc +++ b/src/v/cluster/scheduling/leader_balancer.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer.h b/src/v/cluster/scheduling/leader_balancer.h index 145c0a0ae2dc..a9b51f899d52 100644 --- a/src/v/cluster/scheduling/leader_balancer.h +++ b/src/v/cluster/scheduling/leader_balancer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer_probe.cc b/src/v/cluster/scheduling/leader_balancer_probe.cc index 8661bf67b2d1..93bae6d38952 100644 --- a/src/v/cluster/scheduling/leader_balancer_probe.cc +++ b/src/v/cluster/scheduling/leader_balancer_probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer_probe.h b/src/v/cluster/scheduling/leader_balancer_probe.h index 803d3b36ae4a..b75eb6777cae 100644 --- a/src/v/cluster/scheduling/leader_balancer_probe.h +++ b/src/v/cluster/scheduling/leader_balancer_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer_strategy.h b/src/v/cluster/scheduling/leader_balancer_strategy.h index 71c5aa9a6426..37ed37c75c0c 100644 --- a/src/v/cluster/scheduling/leader_balancer_strategy.h +++ b/src/v/cluster/scheduling/leader_balancer_strategy.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/partition_allocator.cc b/src/v/cluster/scheduling/partition_allocator.cc index 4b4395fc5833..9a605a8fd706 100644 --- a/src/v/cluster/scheduling/partition_allocator.cc +++ b/src/v/cluster/scheduling/partition_allocator.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/partition_allocator.h b/src/v/cluster/scheduling/partition_allocator.h index c332e953ce3d..10c2d4cdc212 100644 --- a/src/v/cluster/scheduling/partition_allocator.h +++ b/src/v/cluster/scheduling/partition_allocator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/types.cc b/src/v/cluster/scheduling/types.cc index 641dd385b748..9ed61b438840 100644 --- a/src/v/cluster/scheduling/types.cc +++ b/src/v/cluster/scheduling/types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/types.h b/src/v/cluster/scheduling/types.h index 04711bb2590a..c99236fceaf2 100644 --- a/src/v/cluster/scheduling/types.h +++ b/src/v/cluster/scheduling/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/security_frontend.cc b/src/v/cluster/security_frontend.cc index 83da17843f89..53e2a0f6e8d5 100644 --- a/src/v/cluster/security_frontend.cc +++ b/src/v/cluster/security_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/security_frontend.h b/src/v/cluster/security_frontend.h index 04e9a4056f3d..3a3c828ecae9 100644 --- a/src/v/cluster/security_frontend.h +++ b/src/v/cluster/security_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/security_manager.cc b/src/v/cluster/security_manager.cc index 4c6f4eebd81c..15d3de62c297 100644 --- a/src/v/cluster/security_manager.cc +++ b/src/v/cluster/security_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/service.cc b/src/v/cluster/service.cc index 96652b673f6b..50765f632f00 100644 --- a/src/v/cluster/service.cc +++ b/src/v/cluster/service.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/service.h b/src/v/cluster/service.h index ab8544864ccf..96d74fdfd8d4 100644 --- a/src/v/cluster/service.h +++ b/src/v/cluster/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/shard_table.h b/src/v/cluster/shard_table.h index 6dc9101f14a7..8db6e1c33d3e 100644 --- a/src/v/cluster/shard_table.h +++ b/src/v/cluster/shard_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/simple_batch_builder.h b/src/v/cluster/simple_batch_builder.h index c8e7c77b2073..0d13c4774aaf 100644 --- a/src/v/cluster/simple_batch_builder.h +++ b/src/v/cluster/simple_batch_builder.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/allocation_bench.cc b/src/v/cluster/tests/allocation_bench.cc index 4e05dbede85c..e295c2b46966 100644 --- a/src/v/cluster/tests/allocation_bench.cc +++ b/src/v/cluster/tests/allocation_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/autocreate_test.cc b/src/v/cluster/tests/autocreate_test.cc index d02114b70131..acd51af96367 100644 --- a/src/v/cluster/tests/autocreate_test.cc +++ b/src/v/cluster/tests/autocreate_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/cluster_test_fixture.h b/src/v/cluster/tests/cluster_test_fixture.h index 140f79278f6d..575409127bb7 100644 --- a/src/v/cluster/tests/cluster_test_fixture.h +++ b/src/v/cluster/tests/cluster_test_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/cluster_tests.cc b/src/v/cluster/tests/cluster_tests.cc index 4f32ca60ba74..65d38a872a92 100644 --- a/src/v/cluster/tests/cluster_tests.cc +++ b/src/v/cluster/tests/cluster_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/cluster_utils_tests.cc b/src/v/cluster/tests/cluster_utils_tests.cc index db5afcd8314b..289ff0454c0b 100644 --- a/src/v/cluster/tests/cluster_utils_tests.cc +++ b/src/v/cluster/tests/cluster_utils_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/commands_serialization_test.cc b/src/v/cluster/tests/commands_serialization_test.cc index 20aa58df4fc5..18b7ab33b5d0 100644 --- a/src/v/cluster/tests/commands_serialization_test.cc +++ b/src/v/cluster/tests/commands_serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/configuration_change_test.cc b/src/v/cluster/tests/configuration_change_test.cc index abde6bd529ca..159489d17a91 100644 --- a/src/v/cluster/tests/configuration_change_test.cc +++ b/src/v/cluster/tests/configuration_change_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/controller_api_tests.cc b/src/v/cluster/tests/controller_api_tests.cc index 5155b3d252de..e587fbedd138 100644 --- a/src/v/cluster/tests/controller_api_tests.cc +++ b/src/v/cluster/tests/controller_api_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/controller_state_test.cc b/src/v/cluster/tests/controller_state_test.cc index 7e572f688127..16acb3e32450 100644 --- a/src/v/cluster/tests/controller_state_test.cc +++ b/src/v/cluster/tests/controller_state_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/health_monitor_test.cc b/src/v/cluster/tests/health_monitor_test.cc index 10b5399b05e9..65c24393246d 100644 --- a/src/v/cluster/tests/health_monitor_test.cc +++ b/src/v/cluster/tests/health_monitor_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/id_allocator_stm_test.cc b/src/v/cluster/tests/id_allocator_stm_test.cc index 19a8b4c0c08d..114747f98754 100644 --- a/src/v/cluster/tests/id_allocator_stm_test.cc +++ b/src/v/cluster/tests/id_allocator_stm_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/idempotency_tests.cc b/src/v/cluster/tests/idempotency_tests.cc index 0507658300a6..283c5b619e1f 100644 --- a/src/v/cluster/tests/idempotency_tests.cc +++ b/src/v/cluster/tests/idempotency_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/metadata_dissemination_test.cc b/src/v/cluster/tests/metadata_dissemination_test.cc index ddf7cc28ce87..6f64647bdd50 100644 --- a/src/v/cluster/tests/metadata_dissemination_test.cc +++ b/src/v/cluster/tests/metadata_dissemination_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/metadata_dissemination_utils_test.cc b/src/v/cluster/tests/metadata_dissemination_utils_test.cc index 3bcad5a95e62..45a0d50b7d01 100644 --- a/src/v/cluster/tests/metadata_dissemination_utils_test.cc +++ b/src/v/cluster/tests/metadata_dissemination_utils_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/notification_latch_test.cc b/src/v/cluster/tests/notification_latch_test.cc index dd09ab09a072..1f5bab11657d 100644 --- a/src/v/cluster/tests/notification_latch_test.cc +++ b/src/v/cluster/tests/notification_latch_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/partition_allocator_fixture.h b/src/v/cluster/tests/partition_allocator_fixture.h index 07c6518aff31..904b90f98c3c 100644 --- a/src/v/cluster/tests/partition_allocator_fixture.h +++ b/src/v/cluster/tests/partition_allocator_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/partition_allocator_tests.cc b/src/v/cluster/tests/partition_allocator_tests.cc index 2700f564b2d8..26dfc5263b83 100644 --- a/src/v/cluster/tests/partition_allocator_tests.cc +++ b/src/v/cluster/tests/partition_allocator_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/rebalancing_tests_fixture.h b/src/v/cluster/tests/rebalancing_tests_fixture.h index 9bbcc5d00ff5..378b9805e4c1 100644 --- a/src/v/cluster/tests/rebalancing_tests_fixture.h +++ b/src/v/cluster/tests/rebalancing_tests_fixture.h @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/rm_stm_tests.cc b/src/v/cluster/tests/rm_stm_tests.cc index cfaed85a28fe..8a8b87b900c2 100644 --- a/src/v/cluster/tests/rm_stm_tests.cc +++ b/src/v/cluster/tests/rm_stm_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/serialization_rt_test.cc b/src/v/cluster/tests/serialization_rt_test.cc index ea62f315f6cc..2b02a92d109d 100644 --- a/src/v/cluster/tests/serialization_rt_test.cc +++ b/src/v/cluster/tests/serialization_rt_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/simple_batch_builder_test.cc b/src/v/cluster/tests/simple_batch_builder_test.cc index 22ee2914e9e2..c72167536e6b 100644 --- a/src/v/cluster/tests/simple_batch_builder_test.cc +++ b/src/v/cluster/tests/simple_batch_builder_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/tm_stm_tests.cc b/src/v/cluster/tests/tm_stm_tests.cc index bb11e363eed3..1d424e63d6a2 100644 --- a/src/v/cluster/tests/tm_stm_tests.cc +++ b/src/v/cluster/tests/tm_stm_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/topic_table_fixture.h b/src/v/cluster/tests/topic_table_fixture.h index f1b672c5bb0d..b63e10c82393 100644 --- a/src/v/cluster/tests/topic_table_fixture.h +++ b/src/v/cluster/tests/topic_table_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/topic_table_test.cc b/src/v/cluster/tests/topic_table_test.cc index e575ad6565f0..716b2112b83f 100644 --- a/src/v/cluster/tests/topic_table_test.cc +++ b/src/v/cluster/tests/topic_table_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/topic_updates_dispatcher_test.cc b/src/v/cluster/tests/topic_updates_dispatcher_test.cc index ba1f4c52cf5e..0deed42d4b3f 100644 --- a/src/v/cluster/tests/topic_updates_dispatcher_test.cc +++ b/src/v/cluster/tests/topic_updates_dispatcher_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/utils.h b/src/v/cluster/tests/utils.h index f42db9a64635..e37595d19387 100644 --- a/src/v/cluster/tests/utils.h +++ b/src/v/cluster/tests/utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tm_stm.cc b/src/v/cluster/tm_stm.cc index b7fd2d52df34..a163dbea8d58 100644 --- a/src/v/cluster/tm_stm.cc +++ b/src/v/cluster/tm_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tm_stm.h b/src/v/cluster/tm_stm.h index 4fd2dc90d97a..c23fe52abd48 100644 --- a/src/v/cluster/tm_stm.h +++ b/src/v/cluster/tm_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/topic_table.cc b/src/v/cluster/topic_table.cc index bc7892e5a06c..a42c19fc3593 100644 --- a/src/v/cluster/topic_table.cc +++ b/src/v/cluster/topic_table.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/topic_table.h b/src/v/cluster/topic_table.h index f045e24ad8b5..4bc8143c06c2 100644 --- a/src/v/cluster/topic_table.h +++ b/src/v/cluster/topic_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/topic_updates_dispatcher.cc b/src/v/cluster/topic_updates_dispatcher.cc index 8a63c159bdd2..278b427e3a1c 100644 --- a/src/v/cluster/topic_updates_dispatcher.cc +++ b/src/v/cluster/topic_updates_dispatcher.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/topic_updates_dispatcher.h b/src/v/cluster/topic_updates_dispatcher.h index e03699b086e8..ad31d279c1ac 100644 --- a/src/v/cluster/topic_updates_dispatcher.h +++ b/src/v/cluster/topic_updates_dispatcher.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/topics_frontend.cc b/src/v/cluster/topics_frontend.cc index cdf79356270f..b7c5edf13533 100644 --- a/src/v/cluster/topics_frontend.cc +++ b/src/v/cluster/topics_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/topics_frontend.h b/src/v/cluster/topics_frontend.h index 8d0ee7351521..d4359af7972d 100644 --- a/src/v/cluster/topics_frontend.h +++ b/src/v/cluster/topics_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tx_gateway.cc b/src/v/cluster/tx_gateway.cc index 77a1790b42e8..7ed80d292430 100644 --- a/src/v/cluster/tx_gateway.cc +++ b/src/v/cluster/tx_gateway.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tx_gateway.h b/src/v/cluster/tx_gateway.h index 3e42579cd4e2..780f99d72847 100644 --- a/src/v/cluster/tx_gateway.h +++ b/src/v/cluster/tx_gateway.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tx_gateway_frontend.cc b/src/v/cluster/tx_gateway_frontend.cc index e062066576ce..39f3648565de 100644 --- a/src/v/cluster/tx_gateway_frontend.cc +++ b/src/v/cluster/tx_gateway_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/tx_gateway_frontend.h b/src/v/cluster/tx_gateway_frontend.h index ac755f307b6a..9fc906b8be23 100644 --- a/src/v/cluster/tx_gateway_frontend.h +++ b/src/v/cluster/tx_gateway_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tx_utils.h b/src/v/cluster/tx_utils.h index c1846323b280..9450eb4ff4cf 100644 --- a/src/v/cluster/tx_utils.h +++ b/src/v/cluster/tx_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/types.cc b/src/v/cluster/types.cc index af08246d2024..b5b007769119 100644 --- a/src/v/cluster/types.cc +++ b/src/v/cluster/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/types.h b/src/v/cluster/types.h index 88e7d614555e..3995d91c6de0 100644 --- a/src/v/cluster/types.h +++ b/src/v/cluster/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/compression.cc b/src/v/compression/compression.cc index 52d9a01c5196..1710b33e77f1 100644 --- a/src/v/compression/compression.cc +++ b/src/v/compression/compression.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/compression.h b/src/v/compression/compression.h index a5be12fd22cd..203989c3ad78 100644 --- a/src/v/compression/compression.h +++ b/src/v/compression/compression.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/internal/gzip_compressor.cc b/src/v/compression/internal/gzip_compressor.cc index 1aef3113dd19..366d06c92bcd 100644 --- a/src/v/compression/internal/gzip_compressor.cc +++ b/src/v/compression/internal/gzip_compressor.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/internal/gzip_compressor.h b/src/v/compression/internal/gzip_compressor.h index e12c9f8e5d7d..a5a4645c9d80 100644 --- a/src/v/compression/internal/gzip_compressor.h +++ b/src/v/compression/internal/gzip_compressor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/internal/lz4_frame_compressor.cc b/src/v/compression/internal/lz4_frame_compressor.cc index f59b5ae3c0e6..be4f3f255ac9 100644 --- a/src/v/compression/internal/lz4_frame_compressor.cc +++ b/src/v/compression/internal/lz4_frame_compressor.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/internal/lz4_frame_compressor.h b/src/v/compression/internal/lz4_frame_compressor.h index bfb5f373fca6..080a2913a247 100644 --- a/src/v/compression/internal/lz4_frame_compressor.h +++ b/src/v/compression/internal/lz4_frame_compressor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/internal/snappy_java_compressor.cc b/src/v/compression/internal/snappy_java_compressor.cc index 61179d9da8c2..d342d78bb36b 100644 --- a/src/v/compression/internal/snappy_java_compressor.cc +++ b/src/v/compression/internal/snappy_java_compressor.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/internal/snappy_java_compressor.h b/src/v/compression/internal/snappy_java_compressor.h index c1e8c64f4140..d22982b7e3ea 100644 --- a/src/v/compression/internal/snappy_java_compressor.h +++ b/src/v/compression/internal/snappy_java_compressor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/internal/zstd_compressor.h b/src/v/compression/internal/zstd_compressor.h index 2169fde7f16f..456fb9af4a11 100644 --- a/src/v/compression/internal/zstd_compressor.h +++ b/src/v/compression/internal/zstd_compressor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/logger.cc b/src/v/compression/logger.cc index fa48b72d471c..da1a3414e5df 100644 --- a/src/v/compression/logger.cc +++ b/src/v/compression/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/logger.h b/src/v/compression/logger.h index 116973d96462..5615337e12d3 100644 --- a/src/v/compression/logger.h +++ b/src/v/compression/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/snappy_standard_compressor.cc b/src/v/compression/snappy_standard_compressor.cc index 570ceeafbd0e..8a4488873381 100644 --- a/src/v/compression/snappy_standard_compressor.cc +++ b/src/v/compression/snappy_standard_compressor.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/snappy_standard_compressor.h b/src/v/compression/snappy_standard_compressor.h index b02c486635c3..a4ab9aa60d0d 100644 --- a/src/v/compression/snappy_standard_compressor.h +++ b/src/v/compression/snappy_standard_compressor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/stream_zstd.cc b/src/v/compression/stream_zstd.cc index 84a15faf1186..23e51fa1fb10 100644 --- a/src/v/compression/stream_zstd.cc +++ b/src/v/compression/stream_zstd.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/stream_zstd.h b/src/v/compression/stream_zstd.h index 5a0b110cb80c..159e03091abf 100644 --- a/src/v/compression/stream_zstd.h +++ b/src/v/compression/stream_zstd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/compression/tests/zstd_stream_bench.cc b/src/v/compression/tests/zstd_stream_bench.cc index a657abd6ade1..8b793c278c70 100644 --- a/src/v/compression/tests/zstd_stream_bench.cc +++ b/src/v/compression/tests/zstd_stream_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/compression/tests/zstd_tests.cc b/src/v/compression/tests/zstd_tests.cc index 3bb30ffdc2e2..a2abd3583e34 100644 --- a/src/v/compression/tests/zstd_tests.cc +++ b/src/v/compression/tests/zstd_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/base_property.cc b/src/v/config/base_property.cc index fc81b8b5b9d8..7e1359d82961 100644 --- a/src/v/config/base_property.cc +++ b/src/v/config/base_property.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/base_property.h b/src/v/config/base_property.h index 749f95b9f0c6..6841e916e9d5 100644 --- a/src/v/config/base_property.h +++ b/src/v/config/base_property.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/config_store.h b/src/v/config/config_store.h index e106924a9866..1bb851bda387 100644 --- a/src/v/config/config_store.h +++ b/src/v/config/config_store.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/configuration.cc b/src/v/config/configuration.cc index 894da04e9998..8134db9ade92 100644 --- a/src/v/config/configuration.cc +++ b/src/v/config/configuration.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/configuration.h b/src/v/config/configuration.h index b9ab8548be2a..0d754a346681 100644 --- a/src/v/config/configuration.h +++ b/src/v/config/configuration.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/data_directory_path.h b/src/v/config/data_directory_path.h index 749eadc6698d..c4c0f119ef02 100644 --- a/src/v/config/data_directory_path.h +++ b/src/v/config/data_directory_path.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/endpoint_tls_config.h b/src/v/config/endpoint_tls_config.h index 7a977173d0ac..231b3a0a9d69 100644 --- a/src/v/config/endpoint_tls_config.h +++ b/src/v/config/endpoint_tls_config.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/property.h b/src/v/config/property.h index 186cfb429ac9..1b20417a36cc 100644 --- a/src/v/config/property.h +++ b/src/v/config/property.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/rjson_serialization.cc b/src/v/config/rjson_serialization.cc index ddfefc46c25e..1df80517103a 100644 --- a/src/v/config/rjson_serialization.cc +++ b/src/v/config/rjson_serialization.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/rjson_serialization.h b/src/v/config/rjson_serialization.h index 328cd1a05430..92123d765ed5 100644 --- a/src/v/config/rjson_serialization.h +++ b/src/v/config/rjson_serialization.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/seed_server.h b/src/v/config/seed_server.h index e881778986cb..05cda0833991 100644 --- a/src/v/config/seed_server.h +++ b/src/v/config/seed_server.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/tests/advertised_kafka_api_test.cc b/src/v/config/tests/advertised_kafka_api_test.cc index 7cfc14f14218..900fbd85d310 100644 --- a/src/v/config/tests/advertised_kafka_api_test.cc +++ b/src/v/config/tests/advertised_kafka_api_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/tests/config_store_test.cc b/src/v/config/tests/config_store_test.cc index 95504045cf9a..192b209b671d 100644 --- a/src/v/config/tests/config_store_test.cc +++ b/src/v/config/tests/config_store_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/tests/custom_aggregate.h b/src/v/config/tests/custom_aggregate.h index a3d94e189681..dbcbfa88ba88 100644 --- a/src/v/config/tests/custom_aggregate.h +++ b/src/v/config/tests/custom_aggregate.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/tests/seed_server_property_test.cc b/src/v/config/tests/seed_server_property_test.cc index 61025f8a29e0..ff6abb64a35e 100644 --- a/src/v/config/tests/seed_server_property_test.cc +++ b/src/v/config/tests/seed_server_property_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/tests/socket_address_convert_test.cc b/src/v/config/tests/socket_address_convert_test.cc index 332b99692466..a3ae192f0cf8 100644 --- a/src/v/config/tests/socket_address_convert_test.cc +++ b/src/v/config/tests/socket_address_convert_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/tests/tls_config_convert_test.cc b/src/v/config/tests/tls_config_convert_test.cc index e56d6e2650fc..4bd92bf5be55 100644 --- a/src/v/config/tests/tls_config_convert_test.cc +++ b/src/v/config/tests/tls_config_convert_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/tls_config.h b/src/v/config/tls_config.h index bfba63f4ff1a..12ca7bb76d43 100644 --- a/src/v/config/tls_config.h +++ b/src/v/config/tls_config.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/validation_error.h b/src/v/config/validation_error.h index e74110a026f4..4d1996b18396 100644 --- a/src/v/config/validation_error.h +++ b/src/v/config/validation_error.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/api.h b/src/v/coproc/api.h index d51813aa2a8f..91c7ed458cbd 100644 --- a/src/v/coproc/api.h +++ b/src/v/coproc/api.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/errc.h b/src/v/coproc/errc.h index 724da87f5591..905bd44f9220 100644 --- a/src/v/coproc/errc.h +++ b/src/v/coproc/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/event_listener.cc b/src/v/coproc/event_listener.cc index 3ad8ba410099..2648f71b62f2 100644 --- a/src/v/coproc/event_listener.cc +++ b/src/v/coproc/event_listener.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/event_listener.h b/src/v/coproc/event_listener.h index 588f7c69ce21..7859e7eff406 100644 --- a/src/v/coproc/event_listener.h +++ b/src/v/coproc/event_listener.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/logger.cc b/src/v/coproc/logger.cc index d62dc4dcb7e6..926b7423ad98 100644 --- a/src/v/coproc/logger.cc +++ b/src/v/coproc/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Licensed as a Redpanda Enterprise file under the Redpanda Community // License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/logger.h b/src/v/coproc/logger.h index ee61f6b5aaac..d17108568721 100644 --- a/src/v/coproc/logger.h +++ b/src/v/coproc/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/offset_storage_utils.cc b/src/v/coproc/offset_storage_utils.cc index 33935ab1c851..6155242abc5a 100644 --- a/src/v/coproc/offset_storage_utils.cc +++ b/src/v/coproc/offset_storage_utils.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/offset_storage_utils.h b/src/v/coproc/offset_storage_utils.h index 683ed61dd7f2..a53407c4d078 100644 --- a/src/v/coproc/offset_storage_utils.h +++ b/src/v/coproc/offset_storage_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/pacemaker.cc b/src/v/coproc/pacemaker.cc index 2d3b2a45b6fb..628a0e70d619 100644 --- a/src/v/coproc/pacemaker.cc +++ b/src/v/coproc/pacemaker.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/pacemaker.h b/src/v/coproc/pacemaker.h index 55e683929f1c..8998a0b79ea8 100644 --- a/src/v/coproc/pacemaker.h +++ b/src/v/coproc/pacemaker.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context.cc b/src/v/coproc/script_context.cc index 29b72eb5ae09..8533278c2c5c 100644 --- a/src/v/coproc/script_context.cc +++ b/src/v/coproc/script_context.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context.h b/src/v/coproc/script_context.h index 5235763b9fe8..33ac5aecadc2 100644 --- a/src/v/coproc/script_context.h +++ b/src/v/coproc/script_context.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_dispatcher.cc b/src/v/coproc/script_dispatcher.cc index 74056d2eb574..2e1df547fec7 100644 --- a/src/v/coproc/script_dispatcher.cc +++ b/src/v/coproc/script_dispatcher.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/script_dispatcher.h b/src/v/coproc/script_dispatcher.h index f3f80a0d2bc0..2c1a24d78744 100644 --- a/src/v/coproc/script_dispatcher.h +++ b/src/v/coproc/script_dispatcher.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/service.h b/src/v/coproc/service.h index dcbc59e38851..c4a6d4b4680f 100644 --- a/src/v/coproc/service.h +++ b/src/v/coproc/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/shared_script_resources.h b/src/v/coproc/shared_script_resources.h index 67ea2a2added..b72f507bbeb2 100644 --- a/src/v/coproc/shared_script_resources.h +++ b/src/v/coproc/shared_script_resources.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/autocreate_topic_tests.cc b/src/v/coproc/tests/autocreate_topic_tests.cc index 11fce8266a2f..322fbc5e791c 100644 --- a/src/v/coproc/tests/autocreate_topic_tests.cc +++ b/src/v/coproc/tests/autocreate_topic_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/coproc_bench_tests.cc b/src/v/coproc/tests/coproc_bench_tests.cc index 130345546548..3be341f0c2e7 100644 --- a/src/v/coproc/tests/coproc_bench_tests.cc +++ b/src/v/coproc/tests/coproc_bench_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/event_listener_tests.cc b/src/v/coproc/tests/event_listener_tests.cc index 663e612828aa..b8619985346f 100644 --- a/src/v/coproc/tests/event_listener_tests.cc +++ b/src/v/coproc/tests/event_listener_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/failure_recovery_tests.cc b/src/v/coproc/tests/failure_recovery_tests.cc index 8e51acf7d95c..ab3feb6daeb8 100644 --- a/src/v/coproc/tests/failure_recovery_tests.cc +++ b/src/v/coproc/tests/failure_recovery_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/fixtures/coproc_bench_fixture.cc b/src/v/coproc/tests/fixtures/coproc_bench_fixture.cc index 1024c2e01091..a9da9506b791 100644 --- a/src/v/coproc/tests/fixtures/coproc_bench_fixture.cc +++ b/src/v/coproc/tests/fixtures/coproc_bench_fixture.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/coproc_bench_fixture.h b/src/v/coproc/tests/fixtures/coproc_bench_fixture.h index a5b79b11cbfa..e69c0ae82f15 100644 --- a/src/v/coproc/tests/fixtures/coproc_bench_fixture.h +++ b/src/v/coproc/tests/fixtures/coproc_bench_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/coproc_test_fixture.cc b/src/v/coproc/tests/fixtures/coproc_test_fixture.cc index 94e4be7fcc4a..d74f1b9c4bb6 100644 --- a/src/v/coproc/tests/fixtures/coproc_test_fixture.cc +++ b/src/v/coproc/tests/fixtures/coproc_test_fixture.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/coproc_test_fixture.h b/src/v/coproc/tests/fixtures/coproc_test_fixture.h index c3b785c7a6f2..529e12e33f16 100644 --- a/src/v/coproc/tests/fixtures/coproc_test_fixture.h +++ b/src/v/coproc/tests/fixtures/coproc_test_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/fixtures/supervisor_test_fixture.h b/src/v/coproc/tests/fixtures/supervisor_test_fixture.h index 6ece63cb957c..d5798b42ce8b 100644 --- a/src/v/coproc/tests/fixtures/supervisor_test_fixture.h +++ b/src/v/coproc/tests/fixtures/supervisor_test_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/kafka_api_materialized_tests.cc b/src/v/coproc/tests/kafka_api_materialized_tests.cc index 3e6684821a5e..206bc0eca366 100644 --- a/src/v/coproc/tests/kafka_api_materialized_tests.cc +++ b/src/v/coproc/tests/kafka_api_materialized_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/offset_storage_utils_tests.cc b/src/v/coproc/tests/offset_storage_utils_tests.cc index 27c1400bceed..8e65e23c5904 100644 --- a/src/v/coproc/tests/offset_storage_utils_tests.cc +++ b/src/v/coproc/tests/offset_storage_utils_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/pacemaker_tests.cc b/src/v/coproc/tests/pacemaker_tests.cc index 97e79078b545..da44f0ea237e 100644 --- a/src/v/coproc/tests/pacemaker_tests.cc +++ b/src/v/coproc/tests/pacemaker_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/retry_logic_tests.cc b/src/v/coproc/tests/retry_logic_tests.cc index 24c06e126e82..0e38de3051d3 100644 --- a/src/v/coproc/tests/retry_logic_tests.cc +++ b/src/v/coproc/tests/retry_logic_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/coprocessor.h b/src/v/coproc/tests/utils/coprocessor.h index 848718693b3d..b08c81f1a20f 100644 --- a/src/v/coproc/tests/utils/coprocessor.h +++ b/src/v/coproc/tests/utils/coprocessor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/event_publisher_utils.cc b/src/v/coproc/tests/utils/event_publisher_utils.cc index 461604814105..53b0e5b6cdb8 100644 --- a/src/v/coproc/tests/utils/event_publisher_utils.cc +++ b/src/v/coproc/tests/utils/event_publisher_utils.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/event_publisher_utils.h b/src/v/coproc/tests/utils/event_publisher_utils.h index 00f7bff0cd5b..d60daa22b3dc 100644 --- a/src/v/coproc/tests/utils/event_publisher_utils.h +++ b/src/v/coproc/tests/utils/event_publisher_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/supervisor.cc b/src/v/coproc/tests/utils/supervisor.cc index 76b47b9395b4..ffcbf86ada7c 100644 --- a/src/v/coproc/tests/utils/supervisor.cc +++ b/src/v/coproc/tests/utils/supervisor.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/utils/supervisor.h b/src/v/coproc/tests/utils/supervisor.h index 4102d581b392..0b00683bfc50 100644 --- a/src/v/coproc/tests/utils/supervisor.h +++ b/src/v/coproc/tests/utils/supervisor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/wasm_event_generator.cc b/src/v/coproc/tests/utils/wasm_event_generator.cc index adfadf413c5d..1146ca0794f0 100644 --- a/src/v/coproc/tests/utils/wasm_event_generator.cc +++ b/src/v/coproc/tests/utils/wasm_event_generator.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/wasm_event_generator.h b/src/v/coproc/tests/utils/wasm_event_generator.h index ea0d6f6574f0..2e12d4d49bd2 100644 --- a/src/v/coproc/tests/utils/wasm_event_generator.h +++ b/src/v/coproc/tests/utils/wasm_event_generator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/wasm_event_tests.cc b/src/v/coproc/tests/wasm_event_tests.cc index 1f055bd5ce69..40e7ed102f35 100644 --- a/src/v/coproc/tests/wasm_event_tests.cc +++ b/src/v/coproc/tests/wasm_event_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/types.cc b/src/v/coproc/types.cc index a36f22d7aa67..16ca1cc305e8 100644 --- a/src/v/coproc/types.cc +++ b/src/v/coproc/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Licensed as a Redpanda Enterprise file under the Redpanda Community // License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/types.h b/src/v/coproc/types.h index ba654faeb5bf..3951d7a2b4e9 100644 --- a/src/v/coproc/types.h +++ b/src/v/coproc/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/wasm_event.cc b/src/v/coproc/wasm_event.cc index f2a6fd7131f5..d4a1fedae71c 100644 --- a/src/v/coproc/wasm_event.cc +++ b/src/v/coproc/wasm_event.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/wasm_event.h b/src/v/coproc/wasm_event.h index cc987644840d..ccc284a1f6ec 100644 --- a/src/v/coproc/wasm_event.h +++ b/src/v/coproc/wasm_event.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/finjector/hbadger.cc b/src/v/finjector/hbadger.cc index 56f9e294bc2a..d16d79bdc132 100644 --- a/src/v/finjector/hbadger.cc +++ b/src/v/finjector/hbadger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/finjector/hbadger.h b/src/v/finjector/hbadger.h index ff6f76ada8d1..9dac80542425 100644 --- a/src/v/finjector/hbadger.h +++ b/src/v/finjector/hbadger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/crc32c.h b/src/v/hashing/crc32c.h index 752bbb3c04a4..d56edbb6592f 100644 --- a/src/v/hashing/crc32c.h +++ b/src/v/hashing/crc32c.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/fnv.h b/src/v/hashing/fnv.h index a00d5ed14637..a6d414326a3a 100644 --- a/src/v/hashing/fnv.h +++ b/src/v/hashing/fnv.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/jenkins.h b/src/v/hashing/jenkins.h index ba570129f27f..ce0e7b82b07a 100644 --- a/src/v/hashing/jenkins.h +++ b/src/v/hashing/jenkins.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/jump_consistent_hash.h b/src/v/hashing/jump_consistent_hash.h index e357f47727a8..bbc74edd9ec0 100644 --- a/src/v/hashing/jump_consistent_hash.h +++ b/src/v/hashing/jump_consistent_hash.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/murmur.cc b/src/v/hashing/murmur.cc index ec82065e002d..db4b043704a0 100644 --- a/src/v/hashing/murmur.cc +++ b/src/v/hashing/murmur.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/hashing/murmur.h b/src/v/hashing/murmur.h index 3cd10967cfdc..5244b17074fa 100644 --- a/src/v/hashing/murmur.h +++ b/src/v/hashing/murmur.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/secure.h b/src/v/hashing/secure.h index 2972c198c4f8..a4d1b750496a 100644 --- a/src/v/hashing/secure.h +++ b/src/v/hashing/secure.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/tests/hash_bench.cc b/src/v/hashing/tests/hash_bench.cc index ba557255e705..bc9ba36e0b23 100644 --- a/src/v/hashing/tests/hash_bench.cc +++ b/src/v/hashing/tests/hash_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/hashing/tests/secure_tests.cc b/src/v/hashing/tests/secure_tests.cc index a9e3560222f2..dc387cf7d02b 100644 --- a/src/v/hashing/tests/secure_tests.cc +++ b/src/v/hashing/tests/secure_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/hashing/tests/xx_tests.cc b/src/v/hashing/tests/xx_tests.cc index c5edb323c3d2..4b97d1a29a2d 100644 --- a/src/v/hashing/tests/xx_tests.cc +++ b/src/v/hashing/tests/xx_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/hashing/twang.h b/src/v/hashing/twang.h index debacdc5d242..856355cb646a 100644 --- a/src/v/hashing/twang.h +++ b/src/v/hashing/twang.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/xx.h b/src/v/hashing/xx.h index e658eb5b1829..99ef44534601 100644 --- a/src/v/hashing/xx.h +++ b/src/v/hashing/xx.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/chunk_encoding.cc b/src/v/http/chunk_encoding.cc index 4dae24065078..ed4684222afd 100644 --- a/src/v/http/chunk_encoding.cc +++ b/src/v/http/chunk_encoding.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/chunk_encoding.h b/src/v/http/chunk_encoding.h index 4e8f1b2cc0b2..bd569df88738 100644 --- a/src/v/http/chunk_encoding.h +++ b/src/v/http/chunk_encoding.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/client.cc b/src/v/http/client.cc index 0e4cc568ad74..069ff9247ae8 100644 --- a/src/v/http/client.cc +++ b/src/v/http/client.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/client.h b/src/v/http/client.h index fda85c3d9b30..4636ac20df61 100644 --- a/src/v/http/client.h +++ b/src/v/http/client.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/demo/client.cc b/src/v/http/demo/client.cc index 793096d2c01a..3c8c6198e574 100644 --- a/src/v/http/demo/client.cc +++ b/src/v/http/demo/client.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/demo/echo.py b/src/v/http/demo/echo.py index 9c41d4c012cf..edd05ad0fc7d 100644 --- a/src/v/http/demo/echo.py +++ b/src/v/http/demo/echo.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/v/http/iobuf_body.cc b/src/v/http/iobuf_body.cc index 89255e68a323..b60c230001e6 100644 --- a/src/v/http/iobuf_body.cc +++ b/src/v/http/iobuf_body.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/iobuf_body.h b/src/v/http/iobuf_body.h index 086ad883c95f..b2c3cec27efb 100644 --- a/src/v/http/iobuf_body.h +++ b/src/v/http/iobuf_body.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/logger.cc b/src/v/http/logger.cc index ac89b8dff69e..38478f41efcf 100644 --- a/src/v/http/logger.cc +++ b/src/v/http/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/logger.h b/src/v/http/logger.h index 40c07de0c870..779e8443517b 100644 --- a/src/v/http/logger.h +++ b/src/v/http/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/probe.h b/src/v/http/probe.h index 6ed24a9388ec..fd3f8aa7be42 100644 --- a/src/v/http/probe.h +++ b/src/v/http/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/http/tests/framing_test.cc b/src/v/http/tests/framing_test.cc index c15914ed9e5b..a6d2d7090935 100644 --- a/src/v/http/tests/framing_test.cc +++ b/src/v/http/tests/framing_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/http/tests/http_client_test.cc b/src/v/http/tests/http_client_test.cc index 20d299e36d70..a6ad846c2e21 100644 --- a/src/v/http/tests/http_client_test.cc +++ b/src/v/http/tests/http_client_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/json/json.cc b/src/v/json/json.cc index 4ee33009df9c..bc61c69deb40 100644 --- a/src/v/json/json.cc +++ b/src/v/json/json.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/json/json.h b/src/v/json/json.h index b943d5798ec5..32096ef34359 100644 --- a/src/v/json/json.h +++ b/src/v/json/json.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/json/tests/json_serialization_test.cc b/src/v/json/tests/json_serialization_test.cc index c86d8007a107..218c00ffcb2d 100644 --- a/src/v/json/tests/json_serialization_test.cc +++ b/src/v/json/tests/json_serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/assignment_plans.cc b/src/v/kafka/client/assignment_plans.cc index 7d502f67230f..1b009248fab3 100644 --- a/src/v/kafka/client/assignment_plans.cc +++ b/src/v/kafka/client/assignment_plans.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/assignment_plans.h b/src/v/kafka/client/assignment_plans.h index 61f29899b976..0aadfc44401e 100644 --- a/src/v/kafka/client/assignment_plans.h +++ b/src/v/kafka/client/assignment_plans.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/broker.cc b/src/v/kafka/client/broker.cc index cb6a5f4110ad..bc69c9f76334 100644 --- a/src/v/kafka/client/broker.cc +++ b/src/v/kafka/client/broker.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/broker.h b/src/v/kafka/client/broker.h index 452c2cb90a5b..9048fb2cac02 100644 --- a/src/v/kafka/client/broker.h +++ b/src/v/kafka/client/broker.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/brokers.cc b/src/v/kafka/client/brokers.cc index 45e2bec9d4d3..5e66f150df6e 100644 --- a/src/v/kafka/client/brokers.cc +++ b/src/v/kafka/client/brokers.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/brokers.h b/src/v/kafka/client/brokers.h index 54e42c5655fa..ac75742ae8df 100644 --- a/src/v/kafka/client/brokers.h +++ b/src/v/kafka/client/brokers.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/client.cc b/src/v/kafka/client/client.cc index 55eac9875bdd..1547c22a10ef 100644 --- a/src/v/kafka/client/client.cc +++ b/src/v/kafka/client/client.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/client.h b/src/v/kafka/client/client.h index 21d88e8bb25c..8f5f70fac05d 100644 --- a/src/v/kafka/client/client.h +++ b/src/v/kafka/client/client.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/configuration.cc b/src/v/kafka/client/configuration.cc index 5f5773195556..4ed39b73f16c 100644 --- a/src/v/kafka/client/configuration.cc +++ b/src/v/kafka/client/configuration.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/configuration.h b/src/v/kafka/client/configuration.h index 12de826c3f87..372fe99f3769 100644 --- a/src/v/kafka/client/configuration.h +++ b/src/v/kafka/client/configuration.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/consumer.cc b/src/v/kafka/client/consumer.cc index dab043abcf3e..8a591d143730 100644 --- a/src/v/kafka/client/consumer.cc +++ b/src/v/kafka/client/consumer.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/consumer.h b/src/v/kafka/client/consumer.h index f0ae82f0aa69..168d324d0d32 100644 --- a/src/v/kafka/client/consumer.h +++ b/src/v/kafka/client/consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/exceptions.h b/src/v/kafka/client/exceptions.h index 83cef3a25b54..b5670910b9d2 100644 --- a/src/v/kafka/client/exceptions.h +++ b/src/v/kafka/client/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/fetch_session.cc b/src/v/kafka/client/fetch_session.cc index afa48e45baf4..4ac6f6ba5480 100644 --- a/src/v/kafka/client/fetch_session.cc +++ b/src/v/kafka/client/fetch_session.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/fetcher.cc b/src/v/kafka/client/fetcher.cc index 8add4c7043cc..edd54287104c 100644 --- a/src/v/kafka/client/fetcher.cc +++ b/src/v/kafka/client/fetcher.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/fetcher.h b/src/v/kafka/client/fetcher.h index 84655cd2c353..6f8334b3be65 100644 --- a/src/v/kafka/client/fetcher.h +++ b/src/v/kafka/client/fetcher.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/logger.h b/src/v/kafka/client/logger.h index c8ced8ba7fcc..61eb592b383b 100644 --- a/src/v/kafka/client/logger.h +++ b/src/v/kafka/client/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/produce_batcher.h b/src/v/kafka/client/produce_batcher.h index 586855e08afd..4ea80ab2875c 100644 --- a/src/v/kafka/client/produce_batcher.h +++ b/src/v/kafka/client/produce_batcher.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/produce_partition.h b/src/v/kafka/client/produce_partition.h index 91a10a09bef3..4a72b40f5440 100644 --- a/src/v/kafka/client/produce_partition.h +++ b/src/v/kafka/client/produce_partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/producer.cc b/src/v/kafka/client/producer.cc index 009d0445db64..cd141a5fb4c4 100644 --- a/src/v/kafka/client/producer.cc +++ b/src/v/kafka/client/producer.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/producer.h b/src/v/kafka/client/producer.h index a368ec99168e..b47973653bdd 100644 --- a/src/v/kafka/client/producer.h +++ b/src/v/kafka/client/producer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/retry_with_mitigation.h b/src/v/kafka/client/retry_with_mitigation.h index 7298fc48c99d..5cabb3dd1992 100644 --- a/src/v/kafka/client/retry_with_mitigation.h +++ b/src/v/kafka/client/retry_with_mitigation.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/consumer_group.cc b/src/v/kafka/client/test/consumer_group.cc index 0a2a46f431cd..2afad4cde9ca 100644 --- a/src/v/kafka/client/test/consumer_group.cc +++ b/src/v/kafka/client/test/consumer_group.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/fetch.cc b/src/v/kafka/client/test/fetch.cc index 695f694c2878..26bb48f48dc3 100644 --- a/src/v/kafka/client/test/fetch.cc +++ b/src/v/kafka/client/test/fetch.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/fetch_session.cc b/src/v/kafka/client/test/fetch_session.cc index db2cd5ef4adc..26d667c1293d 100644 --- a/src/v/kafka/client/test/fetch_session.cc +++ b/src/v/kafka/client/test/fetch_session.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/fixture.h b/src/v/kafka/client/test/fixture.h index fa9234517434..074266e75788 100644 --- a/src/v/kafka/client/test/fixture.h +++ b/src/v/kafka/client/test/fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/partitioners.cc b/src/v/kafka/client/test/partitioners.cc index 659b00202f8f..00cedec84b90 100644 --- a/src/v/kafka/client/test/partitioners.cc +++ b/src/v/kafka/client/test/partitioners.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/produce.cc b/src/v/kafka/client/test/produce.cc index 380f8a950489..67207e0765ba 100644 --- a/src/v/kafka/client/test/produce.cc +++ b/src/v/kafka/client/test/produce.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/produce_batcher.cc b/src/v/kafka/client/test/produce_batcher.cc index 30dd645eafcb..3da28fece7cf 100644 --- a/src/v/kafka/client/test/produce_batcher.cc +++ b/src/v/kafka/client/test/produce_batcher.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/produce_partition.cc b/src/v/kafka/client/test/produce_partition.cc index 9b3db9f1c3ae..51bf2ea5d915 100644 --- a/src/v/kafka/client/test/produce_partition.cc +++ b/src/v/kafka/client/test/produce_partition.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/reconnect.cc b/src/v/kafka/client/test/reconnect.cc index a9c1563e0f1f..fb411d733b0f 100644 --- a/src/v/kafka/client/test/reconnect.cc +++ b/src/v/kafka/client/test/reconnect.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/retry_with_mitigation.cc b/src/v/kafka/client/test/retry_with_mitigation.cc index 6b0799b4787e..7c6d70aca769 100644 --- a/src/v/kafka/client/test/retry_with_mitigation.cc +++ b/src/v/kafka/client/test/retry_with_mitigation.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/utils.h b/src/v/kafka/client/test/utils.h index a4d2453fa5c1..71a33ec91f30 100644 --- a/src/v/kafka/client/test/utils.h +++ b/src/v/kafka/client/test/utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/topic_cache.cc b/src/v/kafka/client/topic_cache.cc index 75c80df5ce4f..c1db6a212326 100644 --- a/src/v/kafka/client/topic_cache.cc +++ b/src/v/kafka/client/topic_cache.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/topic_cache.h b/src/v/kafka/client/topic_cache.h index d8edeb00d103..834c3a236819 100644 --- a/src/v/kafka/client/topic_cache.h +++ b/src/v/kafka/client/topic_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/transport.h b/src/v/kafka/client/transport.h index f20c16adb2cd..d82f956edc37 100644 --- a/src/v/kafka/client/transport.h +++ b/src/v/kafka/client/transport.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/add_offsets_to_txn.h b/src/v/kafka/protocol/add_offsets_to_txn.h index 08f2a1e07ce8..3a0ae9043e16 100644 --- a/src/v/kafka/protocol/add_offsets_to_txn.h +++ b/src/v/kafka/protocol/add_offsets_to_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/add_partitions_to_txn.h b/src/v/kafka/protocol/add_partitions_to_txn.h index da5a011126e0..9b01b6e9e12a 100644 --- a/src/v/kafka/protocol/add_partitions_to_txn.h +++ b/src/v/kafka/protocol/add_partitions_to_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/alter_configs.h b/src/v/kafka/protocol/alter_configs.h index 56790dc46690..50dac6edcaac 100644 --- a/src/v/kafka/protocol/alter_configs.h +++ b/src/v/kafka/protocol/alter_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/api_versions.h b/src/v/kafka/protocol/api_versions.h index 2451eea578b6..5ab1faf84cc7 100644 --- a/src/v/kafka/protocol/api_versions.h +++ b/src/v/kafka/protocol/api_versions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/batch_consumer.h b/src/v/kafka/protocol/batch_consumer.h index c07857416dc9..4dbcb04af85b 100644 --- a/src/v/kafka/protocol/batch_consumer.h +++ b/src/v/kafka/protocol/batch_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/batch_reader.cc b/src/v/kafka/protocol/batch_reader.cc index 0a1012dcfcbf..435539028d87 100644 --- a/src/v/kafka/protocol/batch_reader.cc +++ b/src/v/kafka/protocol/batch_reader.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/batch_reader.h b/src/v/kafka/protocol/batch_reader.h index 38fff8cc0cc4..3bee9b4654fd 100644 --- a/src/v/kafka/protocol/batch_reader.h +++ b/src/v/kafka/protocol/batch_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/create_acls.h b/src/v/kafka/protocol/create_acls.h index 9c23f18ef717..1da95001b62e 100644 --- a/src/v/kafka/protocol/create_acls.h +++ b/src/v/kafka/protocol/create_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/create_partitions.h b/src/v/kafka/protocol/create_partitions.h index feb330523d7c..e673b8098359 100644 --- a/src/v/kafka/protocol/create_partitions.h +++ b/src/v/kafka/protocol/create_partitions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/create_topics.h b/src/v/kafka/protocol/create_topics.h index 018af19c1127..2d2ebc918015 100644 --- a/src/v/kafka/protocol/create_topics.h +++ b/src/v/kafka/protocol/create_topics.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/delete_acls.h b/src/v/kafka/protocol/delete_acls.h index 3daf4dff1ea5..4018f241ebd9 100644 --- a/src/v/kafka/protocol/delete_acls.h +++ b/src/v/kafka/protocol/delete_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/delete_groups.h b/src/v/kafka/protocol/delete_groups.h index 5f2373b55d49..e457131a18e5 100644 --- a/src/v/kafka/protocol/delete_groups.h +++ b/src/v/kafka/protocol/delete_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/delete_topics.h b/src/v/kafka/protocol/delete_topics.h index ef563c7d6785..beb6bf93b480 100644 --- a/src/v/kafka/protocol/delete_topics.h +++ b/src/v/kafka/protocol/delete_topics.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/describe_acls.h b/src/v/kafka/protocol/describe_acls.h index 0942d848f34a..63c87143a781 100644 --- a/src/v/kafka/protocol/describe_acls.h +++ b/src/v/kafka/protocol/describe_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/describe_configs.h b/src/v/kafka/protocol/describe_configs.h index fdc1c9c412fb..40c4ee1d8732 100644 --- a/src/v/kafka/protocol/describe_configs.h +++ b/src/v/kafka/protocol/describe_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/describe_groups.h b/src/v/kafka/protocol/describe_groups.h index 5ddc9e656201..58f8b40b1ab2 100644 --- a/src/v/kafka/protocol/describe_groups.h +++ b/src/v/kafka/protocol/describe_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/describe_log_dirs.h b/src/v/kafka/protocol/describe_log_dirs.h index 39335c3341eb..360eab3ff279 100644 --- a/src/v/kafka/protocol/describe_log_dirs.h +++ b/src/v/kafka/protocol/describe_log_dirs.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/end_txn.h b/src/v/kafka/protocol/end_txn.h index e0ed3ba747dc..e3162ac1c685 100644 --- a/src/v/kafka/protocol/end_txn.h +++ b/src/v/kafka/protocol/end_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/errors.cc b/src/v/kafka/protocol/errors.cc index 3424ce18b4bf..d15752b0f6b0 100644 --- a/src/v/kafka/protocol/errors.cc +++ b/src/v/kafka/protocol/errors.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/errors.h b/src/v/kafka/protocol/errors.h index 181806b58ae7..ee77bbc7125b 100644 --- a/src/v/kafka/protocol/errors.h +++ b/src/v/kafka/protocol/errors.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/exceptions.h b/src/v/kafka/protocol/exceptions.h index 0ad08ee9bd5c..af64e5edcbaa 100644 --- a/src/v/kafka/protocol/exceptions.h +++ b/src/v/kafka/protocol/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/fetch.h b/src/v/kafka/protocol/fetch.h index 10b251d9b7ee..2148c19c1652 100644 --- a/src/v/kafka/protocol/fetch.h +++ b/src/v/kafka/protocol/fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/find_coordinator.h b/src/v/kafka/protocol/find_coordinator.h index 52687bb98c97..51025d7d77d3 100644 --- a/src/v/kafka/protocol/find_coordinator.h +++ b/src/v/kafka/protocol/find_coordinator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/fwd.h b/src/v/kafka/protocol/fwd.h index 866edc901467..f636405172e9 100644 --- a/src/v/kafka/protocol/fwd.h +++ b/src/v/kafka/protocol/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/heartbeat.h b/src/v/kafka/protocol/heartbeat.h index 09519fd6469a..ccc281840855 100644 --- a/src/v/kafka/protocol/heartbeat.h +++ b/src/v/kafka/protocol/heartbeat.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/incremental_alter_configs.h b/src/v/kafka/protocol/incremental_alter_configs.h index 60c4ac569fc0..c0fe44fb31a8 100644 --- a/src/v/kafka/protocol/incremental_alter_configs.h +++ b/src/v/kafka/protocol/incremental_alter_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/init_producer_id.h b/src/v/kafka/protocol/init_producer_id.h index 656329ea5576..f630b7d3666f 100644 --- a/src/v/kafka/protocol/init_producer_id.h +++ b/src/v/kafka/protocol/init_producer_id.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/join_group.h b/src/v/kafka/protocol/join_group.h index ab952dc4a7cc..289a60ccd3ad 100644 --- a/src/v/kafka/protocol/join_group.h +++ b/src/v/kafka/protocol/join_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/kafka_batch_adapter.cc b/src/v/kafka/protocol/kafka_batch_adapter.cc index 68ae69704baa..2a80b421b5f3 100644 --- a/src/v/kafka/protocol/kafka_batch_adapter.cc +++ b/src/v/kafka/protocol/kafka_batch_adapter.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/kafka_batch_adapter.h b/src/v/kafka/protocol/kafka_batch_adapter.h index 1331ae982ed6..79cc26d2e9b3 100644 --- a/src/v/kafka/protocol/kafka_batch_adapter.h +++ b/src/v/kafka/protocol/kafka_batch_adapter.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/leave_group.h b/src/v/kafka/protocol/leave_group.h index 19ab538def38..d85bb9db970b 100644 --- a/src/v/kafka/protocol/leave_group.h +++ b/src/v/kafka/protocol/leave_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/list_groups.h b/src/v/kafka/protocol/list_groups.h index 6d72b202182b..a9150f941be4 100644 --- a/src/v/kafka/protocol/list_groups.h +++ b/src/v/kafka/protocol/list_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/list_offsets.h b/src/v/kafka/protocol/list_offsets.h index 93a355f9e30b..a1bb8190456c 100644 --- a/src/v/kafka/protocol/list_offsets.h +++ b/src/v/kafka/protocol/list_offsets.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/metadata.h b/src/v/kafka/protocol/metadata.h index 5583b2d7f7eb..3613d43c35eb 100644 --- a/src/v/kafka/protocol/metadata.h +++ b/src/v/kafka/protocol/metadata.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/offset_commit.h b/src/v/kafka/protocol/offset_commit.h index f451187b869c..dbc5fcf2ef5c 100644 --- a/src/v/kafka/protocol/offset_commit.h +++ b/src/v/kafka/protocol/offset_commit.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/offset_fetch.h b/src/v/kafka/protocol/offset_fetch.h index 54866a5d44c0..497146f50590 100644 --- a/src/v/kafka/protocol/offset_fetch.h +++ b/src/v/kafka/protocol/offset_fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/offset_for_leader_epoch.h b/src/v/kafka/protocol/offset_for_leader_epoch.h index 3183cccb9bb0..cbb7962671df 100644 --- a/src/v/kafka/protocol/offset_for_leader_epoch.h +++ b/src/v/kafka/protocol/offset_for_leader_epoch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/produce.h b/src/v/kafka/protocol/produce.h index 744e47e879d3..30f2796bbf62 100644 --- a/src/v/kafka/protocol/produce.h +++ b/src/v/kafka/protocol/produce.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/request_reader.h b/src/v/kafka/protocol/request_reader.h index 31c88570481d..51a70a1d008f 100644 --- a/src/v/kafka/protocol/request_reader.h +++ b/src/v/kafka/protocol/request_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/response_writer.h b/src/v/kafka/protocol/response_writer.h index 94b887d7519a..19546b639802 100644 --- a/src/v/kafka/protocol/response_writer.h +++ b/src/v/kafka/protocol/response_writer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/sasl_authenticate.h b/src/v/kafka/protocol/sasl_authenticate.h index 3f7a7424678e..971961f922b0 100644 --- a/src/v/kafka/protocol/sasl_authenticate.h +++ b/src/v/kafka/protocol/sasl_authenticate.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/sasl_handshake.h b/src/v/kafka/protocol/sasl_handshake.h index 48168a412e96..d23681785c8a 100644 --- a/src/v/kafka/protocol/sasl_handshake.h +++ b/src/v/kafka/protocol/sasl_handshake.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/schemata/generator.py b/src/v/kafka/protocol/schemata/generator.py index 74cbf2beb847..554b8ffb592b 100644 --- a/src/v/kafka/protocol/schemata/generator.py +++ b/src/v/kafka/protocol/schemata/generator.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/sync_group.h b/src/v/kafka/protocol/sync_group.h index ec191c149b09..5d9d0a4ec8af 100644 --- a/src/v/kafka/protocol/sync_group.h +++ b/src/v/kafka/protocol/sync_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/tests/batch_reader_test.cc b/src/v/kafka/protocol/tests/batch_reader_test.cc index c919135e1f89..79a466808928 100644 --- a/src/v/kafka/protocol/tests/batch_reader_test.cc +++ b/src/v/kafka/protocol/tests/batch_reader_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/tests/security_test.cc b/src/v/kafka/protocol/tests/security_test.cc index 91474a7ad3bb..5ec8f2bbd13f 100644 --- a/src/v/kafka/protocol/tests/security_test.cc +++ b/src/v/kafka/protocol/tests/security_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/timeout.h b/src/v/kafka/protocol/timeout.h index f6b776cc7c02..46f35480fd15 100644 --- a/src/v/kafka/protocol/timeout.h +++ b/src/v/kafka/protocol/timeout.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/txn_offset_commit.h b/src/v/kafka/protocol/txn_offset_commit.h index b0a1204c589e..0495c17b904b 100644 --- a/src/v/kafka/protocol/txn_offset_commit.h +++ b/src/v/kafka/protocol/txn_offset_commit.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/types.h b/src/v/kafka/protocol/types.h index fc68b8da0e24..758e7f37ec3e 100644 --- a/src/v/kafka/protocol/types.h +++ b/src/v/kafka/protocol/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/connection_context.cc b/src/v/kafka/server/connection_context.cc index 779976241fae..c0fa11ec52d9 100644 --- a/src/v/kafka/server/connection_context.cc +++ b/src/v/kafka/server/connection_context.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/connection_context.h b/src/v/kafka/server/connection_context.h index 540dc6820321..7ee9c6440d2a 100644 --- a/src/v/kafka/server/connection_context.h +++ b/src/v/kafka/server/connection_context.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/coordinator_ntp_mapper.h b/src/v/kafka/server/coordinator_ntp_mapper.h index 57c954145a46..9953c563b8e2 100644 --- a/src/v/kafka/server/coordinator_ntp_mapper.h +++ b/src/v/kafka/server/coordinator_ntp_mapper.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/fetch_metadata_cache.hh b/src/v/kafka/server/fetch_metadata_cache.hh index d96db2337cd0..8ce42eb6610c 100644 --- a/src/v/kafka/server/fetch_metadata_cache.hh +++ b/src/v/kafka/server/fetch_metadata_cache.hh @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/fetch_session.h b/src/v/kafka/server/fetch_session.h index 8dbca7f2d15c..65eb0f8fa262 100644 --- a/src/v/kafka/server/fetch_session.h +++ b/src/v/kafka/server/fetch_session.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/fetch_session_cache.h b/src/v/kafka/server/fetch_session_cache.h index 845be6e70107..f90b7e60f582 100644 --- a/src/v/kafka/server/fetch_session_cache.h +++ b/src/v/kafka/server/fetch_session_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/fwd.h b/src/v/kafka/server/fwd.h index 3e8702ebb109..a893be15ed16 100644 --- a/src/v/kafka/server/fwd.h +++ b/src/v/kafka/server/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group.cc b/src/v/kafka/server/group.cc index a31648fc51c2..b9db73f81bd7 100644 --- a/src/v/kafka/server/group.cc +++ b/src/v/kafka/server/group.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group.h b/src/v/kafka/server/group.h index 7ef052db875e..15254897a33d 100644 --- a/src/v/kafka/server/group.h +++ b/src/v/kafka/server/group.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_manager.cc b/src/v/kafka/server/group_manager.cc index 6f8e590d684b..7977c2b38e45 100644 --- a/src/v/kafka/server/group_manager.cc +++ b/src/v/kafka/server/group_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_manager.h b/src/v/kafka/server/group_manager.h index 04ab0131a391..cb3db65e5472 100644 --- a/src/v/kafka/server/group_manager.h +++ b/src/v/kafka/server/group_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_metadata.cc b/src/v/kafka/server/group_metadata.cc index 7de71944a1e9..ccc5587e3451 100644 --- a/src/v/kafka/server/group_metadata.cc +++ b/src/v/kafka/server/group_metadata.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_metadata.h b/src/v/kafka/server/group_metadata.h index 2e246081aee2..f238fb6f34fe 100644 --- a/src/v/kafka/server/group_metadata.h +++ b/src/v/kafka/server/group_metadata.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_metadata_migration.h b/src/v/kafka/server/group_metadata_migration.h index 5c57c50bf7d5..8d7b898fa31b 100644 --- a/src/v/kafka/server/group_metadata_migration.h +++ b/src/v/kafka/server/group_metadata_migration.h @@ -1,6 +1,6 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_recovery_consumer.cc b/src/v/kafka/server/group_recovery_consumer.cc index 1f9422503659..0852dbef8dc5 100644 --- a/src/v/kafka/server/group_recovery_consumer.cc +++ b/src/v/kafka/server/group_recovery_consumer.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_recovery_consumer.h b/src/v/kafka/server/group_recovery_consumer.h index c29668140190..ae134ae68596 100644 --- a/src/v/kafka/server/group_recovery_consumer.h +++ b/src/v/kafka/server/group_recovery_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_router.cc b/src/v/kafka/server/group_router.cc index 9213f8ff4c38..853514d01fb9 100644 --- a/src/v/kafka/server/group_router.cc +++ b/src/v/kafka/server/group_router.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/group_router.h b/src/v/kafka/server/group_router.h index b9abbda38c59..0358aa7f118d 100644 --- a/src/v/kafka/server/group_router.h +++ b/src/v/kafka/server/group_router.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/add_offsets_to_txn.cc b/src/v/kafka/server/handlers/add_offsets_to_txn.cc index 154f26229707..2655166b0600 100644 --- a/src/v/kafka/server/handlers/add_offsets_to_txn.cc +++ b/src/v/kafka/server/handlers/add_offsets_to_txn.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/add_partitions_to_txn.cc b/src/v/kafka/server/handlers/add_partitions_to_txn.cc index 891fbed29d14..4ec27fe5a495 100644 --- a/src/v/kafka/server/handlers/add_partitions_to_txn.cc +++ b/src/v/kafka/server/handlers/add_partitions_to_txn.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/alter_configs.cc b/src/v/kafka/server/handlers/alter_configs.cc index 9e0d0647d749..4e5ae55042c2 100644 --- a/src/v/kafka/server/handlers/alter_configs.cc +++ b/src/v/kafka/server/handlers/alter_configs.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/api_versions.cc b/src/v/kafka/server/handlers/api_versions.cc index 4ce4566b31a0..1727249644a5 100644 --- a/src/v/kafka/server/handlers/api_versions.cc +++ b/src/v/kafka/server/handlers/api_versions.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_partitions.cc b/src/v/kafka/server/handlers/create_partitions.cc index c0432cc5d0d5..8f63abe89b70 100644 --- a/src/v/kafka/server/handlers/create_partitions.cc +++ b/src/v/kafka/server/handlers/create_partitions.cc @@ -1,5 +1,5 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_topics.cc b/src/v/kafka/server/handlers/create_topics.cc index a78279f96432..005d45f0cbee 100644 --- a/src/v/kafka/server/handlers/create_topics.cc +++ b/src/v/kafka/server/handlers/create_topics.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_groups.cc b/src/v/kafka/server/handlers/delete_groups.cc index af4389cce577..d070b92734a4 100644 --- a/src/v/kafka/server/handlers/delete_groups.cc +++ b/src/v/kafka/server/handlers/delete_groups.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_topics.cc b/src/v/kafka/server/handlers/delete_topics.cc index aacb214f3903..9ce994206315 100644 --- a/src/v/kafka/server/handlers/delete_topics.cc +++ b/src/v/kafka/server/handlers/delete_topics.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_configs.cc b/src/v/kafka/server/handlers/describe_configs.cc index 84f8ffb51ddf..3344aebd611c 100644 --- a/src/v/kafka/server/handlers/describe_configs.cc +++ b/src/v/kafka/server/handlers/describe_configs.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_groups.cc b/src/v/kafka/server/handlers/describe_groups.cc index 9c96ec37f9e6..91954ab01166 100644 --- a/src/v/kafka/server/handlers/describe_groups.cc +++ b/src/v/kafka/server/handlers/describe_groups.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/end_txn.cc b/src/v/kafka/server/handlers/end_txn.cc index bbc06afa39a0..991dde902f25 100644 --- a/src/v/kafka/server/handlers/end_txn.cc +++ b/src/v/kafka/server/handlers/end_txn.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/fetch.cc b/src/v/kafka/server/handlers/fetch.cc index fe34c2670eb1..159960dfe526 100644 --- a/src/v/kafka/server/handlers/fetch.cc +++ b/src/v/kafka/server/handlers/fetch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/fetch/fetch_plan_executor.h b/src/v/kafka/server/handlers/fetch/fetch_plan_executor.h index 72900e0bfb28..d17e01f2bac0 100644 --- a/src/v/kafka/server/handlers/fetch/fetch_plan_executor.h +++ b/src/v/kafka/server/handlers/fetch/fetch_plan_executor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/fetch/fetch_planner.h b/src/v/kafka/server/handlers/fetch/fetch_planner.h index 6f300502848c..7f04e32521b7 100644 --- a/src/v/kafka/server/handlers/fetch/fetch_planner.h +++ b/src/v/kafka/server/handlers/fetch/fetch_planner.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/find_coordinator.cc b/src/v/kafka/server/handlers/find_coordinator.cc index 0bee2705a3bc..87a72f661c39 100644 --- a/src/v/kafka/server/handlers/find_coordinator.cc +++ b/src/v/kafka/server/handlers/find_coordinator.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/heartbeat.cc b/src/v/kafka/server/handlers/heartbeat.cc index 34c2b99e992f..1b5df405ebf3 100644 --- a/src/v/kafka/server/handlers/heartbeat.cc +++ b/src/v/kafka/server/handlers/heartbeat.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/incremental_alter_configs.cc b/src/v/kafka/server/handlers/incremental_alter_configs.cc index f4bf1f595b65..3614993002a9 100644 --- a/src/v/kafka/server/handlers/incremental_alter_configs.cc +++ b/src/v/kafka/server/handlers/incremental_alter_configs.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/init_producer_id.cc b/src/v/kafka/server/handlers/init_producer_id.cc index b03b7922b395..2ec66b234aea 100644 --- a/src/v/kafka/server/handlers/init_producer_id.cc +++ b/src/v/kafka/server/handlers/init_producer_id.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/join_group.cc b/src/v/kafka/server/handlers/join_group.cc index fe79306da70c..9106545c5736 100644 --- a/src/v/kafka/server/handlers/join_group.cc +++ b/src/v/kafka/server/handlers/join_group.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/leave_group.cc b/src/v/kafka/server/handlers/leave_group.cc index 34bd9cfc32c2..fe290a2dbf40 100644 --- a/src/v/kafka/server/handlers/leave_group.cc +++ b/src/v/kafka/server/handlers/leave_group.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/list_groups.cc b/src/v/kafka/server/handlers/list_groups.cc index 18bc3206a463..ed1dbc87658c 100644 --- a/src/v/kafka/server/handlers/list_groups.cc +++ b/src/v/kafka/server/handlers/list_groups.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/list_offsets.cc b/src/v/kafka/server/handlers/list_offsets.cc index dfd05ad8a720..cd7c8e3a9a6d 100644 --- a/src/v/kafka/server/handlers/list_offsets.cc +++ b/src/v/kafka/server/handlers/list_offsets.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/metadata.cc b/src/v/kafka/server/handlers/metadata.cc index cb34e7329cfc..1ed854627135 100644 --- a/src/v/kafka/server/handlers/metadata.cc +++ b/src/v/kafka/server/handlers/metadata.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_commit.cc b/src/v/kafka/server/handlers/offset_commit.cc index c9e0b4107568..731c4e61a0e7 100644 --- a/src/v/kafka/server/handlers/offset_commit.cc +++ b/src/v/kafka/server/handlers/offset_commit.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_fetch.cc b/src/v/kafka/server/handlers/offset_fetch.cc index 708b90a618fb..b4a39087bd7c 100644 --- a/src/v/kafka/server/handlers/offset_fetch.cc +++ b/src/v/kafka/server/handlers/offset_fetch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_for_leader_epoch.cc b/src/v/kafka/server/handlers/offset_for_leader_epoch.cc index 990755e4cf7b..35ebb5584d6b 100644 --- a/src/v/kafka/server/handlers/offset_for_leader_epoch.cc +++ b/src/v/kafka/server/handlers/offset_for_leader_epoch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/produce.cc b/src/v/kafka/server/handlers/produce.cc index f381f96ff1af..d4eb6dba682e 100644 --- a/src/v/kafka/server/handlers/produce.cc +++ b/src/v/kafka/server/handlers/produce.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sasl_authenticate.cc b/src/v/kafka/server/handlers/sasl_authenticate.cc index e0f720418da6..4634fda0fc72 100644 --- a/src/v/kafka/server/handlers/sasl_authenticate.cc +++ b/src/v/kafka/server/handlers/sasl_authenticate.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sasl_handshake.cc b/src/v/kafka/server/handlers/sasl_handshake.cc index e81d984e2cc9..6e9bddef040a 100644 --- a/src/v/kafka/server/handlers/sasl_handshake.cc +++ b/src/v/kafka/server/handlers/sasl_handshake.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sync_group.cc b/src/v/kafka/server/handlers/sync_group.cc index 903569339706..9ae4489b91e8 100644 --- a/src/v/kafka/server/handlers/sync_group.cc +++ b/src/v/kafka/server/handlers/sync_group.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/topics/topic_utils.cc b/src/v/kafka/server/handlers/topics/topic_utils.cc index f2abb82a3e71..7a5362dd4362 100644 --- a/src/v/kafka/server/handlers/topics/topic_utils.cc +++ b/src/v/kafka/server/handlers/topics/topic_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/topics/topic_utils.h b/src/v/kafka/server/handlers/topics/topic_utils.h index c61c37f14a9a..bfdb3a42cbc4 100644 --- a/src/v/kafka/server/handlers/topics/topic_utils.h +++ b/src/v/kafka/server/handlers/topics/topic_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/topics/types.cc b/src/v/kafka/server/handlers/topics/types.cc index b6d9577d23b8..0c6cea8ff144 100644 --- a/src/v/kafka/server/handlers/topics/types.cc +++ b/src/v/kafka/server/handlers/topics/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/topics/types.h b/src/v/kafka/server/handlers/topics/types.h index 798e50435423..1afe3baf5156 100644 --- a/src/v/kafka/server/handlers/topics/types.h +++ b/src/v/kafka/server/handlers/topics/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/topics/validators.h b/src/v/kafka/server/handlers/topics/validators.h index dcbca11595fc..6d3715b51977 100644 --- a/src/v/kafka/server/handlers/topics/validators.h +++ b/src/v/kafka/server/handlers/topics/validators.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/txn_offset_commit.cc b/src/v/kafka/server/handlers/txn_offset_commit.cc index 36a297b5e88d..d2f7fe586485 100644 --- a/src/v/kafka/server/handlers/txn_offset_commit.cc +++ b/src/v/kafka/server/handlers/txn_offset_commit.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/logger.cc b/src/v/kafka/server/logger.cc index 6574d5e5fda7..1713e23d2ea6 100644 --- a/src/v/kafka/server/logger.cc +++ b/src/v/kafka/server/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/logger.h b/src/v/kafka/server/logger.h index def0f75e0653..94126cff35c2 100644 --- a/src/v/kafka/server/logger.h +++ b/src/v/kafka/server/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/member.cc b/src/v/kafka/server/member.cc index cdbb3ab03b60..a608e686d9c3 100644 --- a/src/v/kafka/server/member.cc +++ b/src/v/kafka/server/member.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/member.h b/src/v/kafka/server/member.h index 9e54d071f4db..c80c6410a7dc 100644 --- a/src/v/kafka/server/member.h +++ b/src/v/kafka/server/member.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/protocol.cc b/src/v/kafka/server/protocol.cc index 2e8f0115a25d..a36d9cf5d6d5 100644 --- a/src/v/kafka/server/protocol.cc +++ b/src/v/kafka/server/protocol.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/protocol.h b/src/v/kafka/server/protocol.h index 5af7bc9ea8e7..84ba9aced12d 100644 --- a/src/v/kafka/server/protocol.h +++ b/src/v/kafka/server/protocol.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/protocol_utils.cc b/src/v/kafka/server/protocol_utils.cc index f2b803071d71..281a3b0dbbe8 100644 --- a/src/v/kafka/server/protocol_utils.cc +++ b/src/v/kafka/server/protocol_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/protocol_utils.h b/src/v/kafka/server/protocol_utils.h index 0cbac715eeca..c74d140464e7 100644 --- a/src/v/kafka/server/protocol_utils.h +++ b/src/v/kafka/server/protocol_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/quota_manager.cc b/src/v/kafka/server/quota_manager.cc index e234613ee0d2..87caa95bba70 100644 --- a/src/v/kafka/server/quota_manager.cc +++ b/src/v/kafka/server/quota_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/quota_manager.h b/src/v/kafka/server/quota_manager.h index 80f5608071d3..2f265dff894c 100644 --- a/src/v/kafka/server/quota_manager.h +++ b/src/v/kafka/server/quota_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/request_context.h b/src/v/kafka/server/request_context.h index a50ebbfa9c65..0cffa1ca7fa8 100644 --- a/src/v/kafka/server/request_context.h +++ b/src/v/kafka/server/request_context.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/requests.cc b/src/v/kafka/server/requests.cc index bce4d24d2487..aa5eff05cc08 100644 --- a/src/v/kafka/server/requests.cc +++ b/src/v/kafka/server/requests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/response.h b/src/v/kafka/server/response.h index 9b43a4721ef3..67fe45cee2c4 100644 --- a/src/v/kafka/server/response.h +++ b/src/v/kafka/server/response.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/rm_group_frontend.cc b/src/v/kafka/server/rm_group_frontend.cc index 8fba28da758c..9cd74b8a10a1 100644 --- a/src/v/kafka/server/rm_group_frontend.cc +++ b/src/v/kafka/server/rm_group_frontend.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/rm_group_frontend.h b/src/v/kafka/server/rm_group_frontend.h index 87e271860ea0..82735aeb489c 100644 --- a/src/v/kafka/server/rm_group_frontend.h +++ b/src/v/kafka/server/rm_group_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/alter_config_test.cc b/src/v/kafka/server/tests/alter_config_test.cc index 4f8696c2c85d..a8c2c137a918 100644 --- a/src/v/kafka/server/tests/alter_config_test.cc +++ b/src/v/kafka/server/tests/alter_config_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/api_versions_test.cc b/src/v/kafka/server/tests/api_versions_test.cc index e0c75c560180..38a2f738cf4f 100644 --- a/src/v/kafka/server/tests/api_versions_test.cc +++ b/src/v/kafka/server/tests/api_versions_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/create_topics_test.cc b/src/v/kafka/server/tests/create_topics_test.cc index fb75fa6fdad1..3a1767108bd0 100644 --- a/src/v/kafka/server/tests/create_topics_test.cc +++ b/src/v/kafka/server/tests/create_topics_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/delete_topics_test.cc b/src/v/kafka/server/tests/delete_topics_test.cc index 6216cac6e224..270fbf640601 100644 --- a/src/v/kafka/server/tests/delete_topics_test.cc +++ b/src/v/kafka/server/tests/delete_topics_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/error_mapping_test.cc b/src/v/kafka/server/tests/error_mapping_test.cc index fad38516a34d..04b08f5b9fe0 100644 --- a/src/v/kafka/server/tests/error_mapping_test.cc +++ b/src/v/kafka/server/tests/error_mapping_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/fetch_session_test.cc b/src/v/kafka/server/tests/fetch_session_test.cc index ba00409ee569..c749a552f333 100644 --- a/src/v/kafka/server/tests/fetch_session_test.cc +++ b/src/v/kafka/server/tests/fetch_session_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/fetch_test.cc b/src/v/kafka/server/tests/fetch_test.cc index da8e92496f55..a72bbcdbbae7 100644 --- a/src/v/kafka/server/tests/fetch_test.cc +++ b/src/v/kafka/server/tests/fetch_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/find_coordinator_test.cc b/src/v/kafka/server/tests/find_coordinator_test.cc index 038b33dd353c..b603b3f6ac20 100644 --- a/src/v/kafka/server/tests/find_coordinator_test.cc +++ b/src/v/kafka/server/tests/find_coordinator_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/group_metadata_serialization_test.cc b/src/v/kafka/server/tests/group_metadata_serialization_test.cc index 7d0642b02d49..6c78de55b5d7 100644 --- a/src/v/kafka/server/tests/group_metadata_serialization_test.cc +++ b/src/v/kafka/server/tests/group_metadata_serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/group_test.cc b/src/v/kafka/server/tests/group_test.cc index 5e6332f98c10..eee04377dacb 100644 --- a/src/v/kafka/server/tests/group_test.cc +++ b/src/v/kafka/server/tests/group_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/list_offsets_test.cc b/src/v/kafka/server/tests/list_offsets_test.cc index 18630599368f..f031ffa81aa8 100644 --- a/src/v/kafka/server/tests/list_offsets_test.cc +++ b/src/v/kafka/server/tests/list_offsets_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/member_test.cc b/src/v/kafka/server/tests/member_test.cc index a71ae7e0695f..0694ad507332 100644 --- a/src/v/kafka/server/tests/member_test.cc +++ b/src/v/kafka/server/tests/member_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/metadata_test.cc b/src/v/kafka/server/tests/metadata_test.cc index 7ddbfeebc6d9..f5ddc2bdb9fb 100644 --- a/src/v/kafka/server/tests/metadata_test.cc +++ b/src/v/kafka/server/tests/metadata_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/offset_commit_test.cc b/src/v/kafka/server/tests/offset_commit_test.cc index 83b2cf46f65c..8ac835a49a0c 100644 --- a/src/v/kafka/server/tests/offset_commit_test.cc +++ b/src/v/kafka/server/tests/offset_commit_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/offset_fetch_test.cc b/src/v/kafka/server/tests/offset_fetch_test.cc index b0b3119d099b..6e15aeb15010 100644 --- a/src/v/kafka/server/tests/offset_fetch_test.cc +++ b/src/v/kafka/server/tests/offset_fetch_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/produce_consume_test.cc b/src/v/kafka/server/tests/produce_consume_test.cc index 95af25bb8e0a..60008c0c04c5 100644 --- a/src/v/kafka/server/tests/produce_consume_test.cc +++ b/src/v/kafka/server/tests/produce_consume_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/read_write_roundtrip_test.cc b/src/v/kafka/server/tests/read_write_roundtrip_test.cc index 512733393634..290c4919568b 100644 --- a/src/v/kafka/server/tests/read_write_roundtrip_test.cc +++ b/src/v/kafka/server/tests/read_write_roundtrip_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/request_parser_test.cc b/src/v/kafka/server/tests/request_parser_test.cc index dfcb0749b7ef..e34ba7b9637a 100644 --- a/src/v/kafka/server/tests/request_parser_test.cc +++ b/src/v/kafka/server/tests/request_parser_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/timeouts_conversion_test.cc b/src/v/kafka/server/tests/timeouts_conversion_test.cc index f8e5ef72b087..9acff84b3c7c 100644 --- a/src/v/kafka/server/tests/timeouts_conversion_test.cc +++ b/src/v/kafka/server/tests/timeouts_conversion_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/topic_recreate_test.cc b/src/v/kafka/server/tests/topic_recreate_test.cc index a0d4c72e6aba..1a0d9835696a 100644 --- a/src/v/kafka/server/tests/topic_recreate_test.cc +++ b/src/v/kafka/server/tests/topic_recreate_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/topic_utils_test.cc b/src/v/kafka/server/tests/topic_utils_test.cc index f172372dc5b5..202cd13e6f50 100644 --- a/src/v/kafka/server/tests/topic_utils_test.cc +++ b/src/v/kafka/server/tests/topic_utils_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/server/tests/types_conversion_tests.cc b/src/v/kafka/server/tests/types_conversion_tests.cc index 5fb4b834bb54..3e17f7234a84 100644 --- a/src/v/kafka/server/tests/types_conversion_tests.cc +++ b/src/v/kafka/server/tests/types_conversion_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/types.h b/src/v/kafka/types.h index e4266110259b..64d68ea94636 100644 --- a/src/v/kafka/types.h +++ b/src/v/kafka/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/likely.h b/src/v/likely.h index d1bfd3810c84..d45a47a760b7 100644 --- a/src/v/likely.h +++ b/src/v/likely.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/adl_serde.cc b/src/v/model/adl_serde.cc index 5828e913867e..460d10d75f2c 100644 --- a/src/v/model/adl_serde.cc +++ b/src/v/model/adl_serde.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/adl_serde.h b/src/v/model/adl_serde.h index 1f5c920696ba..5470cd26fff6 100644 --- a/src/v/model/adl_serde.h +++ b/src/v/model/adl_serde.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/async_adl_serde.cc b/src/v/model/async_adl_serde.cc index 237e0feba55e..52b859693886 100644 --- a/src/v/model/async_adl_serde.cc +++ b/src/v/model/async_adl_serde.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/async_adl_serde.h b/src/v/model/async_adl_serde.h index a13339cd5f9b..e8ef33c26d7e 100644 --- a/src/v/model/async_adl_serde.h +++ b/src/v/model/async_adl_serde.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/compression.h b/src/v/model/compression.h index 92ec8cc97905..1386a40bfc4d 100644 --- a/src/v/model/compression.h +++ b/src/v/model/compression.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/errc.h b/src/v/model/errc.h index 863ebb443b39..899c1e354db7 100644 --- a/src/v/model/errc.h +++ b/src/v/model/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/fundamental.h b/src/v/model/fundamental.h index c459b4799dbf..8a2c9b691cb4 100644 --- a/src/v/model/fundamental.h +++ b/src/v/model/fundamental.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/limits.h b/src/v/model/limits.h index 4a09288b6ebe..77b46e311f7b 100644 --- a/src/v/model/limits.h +++ b/src/v/model/limits.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/metadata.h b/src/v/model/metadata.h index 02ff27d55700..0decd142742c 100644 --- a/src/v/model/metadata.h +++ b/src/v/model/metadata.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/model.cc b/src/v/model/model.cc index 2c540312c442..b60e81130d50 100644 --- a/src/v/model/model.cc +++ b/src/v/model/model.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/namespace.h b/src/v/model/namespace.h index 5ce4a8177099..4932d12135ec 100644 --- a/src/v/model/namespace.h +++ b/src/v/model/namespace.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/record.h b/src/v/model/record.h index af0b8de17b12..e014cf579c66 100644 --- a/src/v/model/record.h +++ b/src/v/model/record.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/record_batch_reader.cc b/src/v/model/record_batch_reader.cc index 17f87f3b0d35..9d1d5ea528da 100644 --- a/src/v/model/record_batch_reader.cc +++ b/src/v/model/record_batch_reader.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/record_batch_reader.h b/src/v/model/record_batch_reader.h index d58195c12db4..0cf823a6dda7 100644 --- a/src/v/model/record_batch_reader.h +++ b/src/v/model/record_batch_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/record_batch_types.h b/src/v/model/record_batch_types.h index 36dc4bb25b41..545f45f18b43 100644 --- a/src/v/model/record_batch_types.h +++ b/src/v/model/record_batch_types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/record_utils.cc b/src/v/model/record_utils.cc index 9f3e9607f022..0ce675a5fb3a 100644 --- a/src/v/model/record_utils.cc +++ b/src/v/model/record_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/record_utils.h b/src/v/model/record_utils.h index ca63b96fe685..f0f671d08a5a 100644 --- a/src/v/model/record_utils.h +++ b/src/v/model/record_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/tests/lexical_cast_tests.cc b/src/v/model/tests/lexical_cast_tests.cc index af5057487f72..4e55fc5582db 100644 --- a/src/v/model/tests/lexical_cast_tests.cc +++ b/src/v/model/tests/lexical_cast_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/tests/model_serialization_test.cc b/src/v/model/tests/model_serialization_test.cc index fe6eb332fc87..d95e6b9b307f 100644 --- a/src/v/model/tests/model_serialization_test.cc +++ b/src/v/model/tests/model_serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/tests/ntp_path_test.cc b/src/v/model/tests/ntp_path_test.cc index 58649e85007f..8a09d8dca24f 100644 --- a/src/v/model/tests/ntp_path_test.cc +++ b/src/v/model/tests/ntp_path_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/tests/record_batch_reader_test.cc b/src/v/model/tests/record_batch_reader_test.cc index 516b093cb2c7..a536423266fd 100644 --- a/src/v/model/tests/record_batch_reader_test.cc +++ b/src/v/model/tests/record_batch_reader_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/tests/record_batch_test.cc b/src/v/model/tests/record_batch_test.cc index 397b91c08358..2c3f0bc74fe6 100644 --- a/src/v/model/tests/record_batch_test.cc +++ b/src/v/model/tests/record_batch_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/tests/topic_view_tests.cc b/src/v/model/tests/topic_view_tests.cc index 48c9635600f7..e92bfb0be8b9 100644 --- a/src/v/model/tests/topic_view_tests.cc +++ b/src/v/model/tests/topic_view_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/timeout_clock.h b/src/v/model/timeout_clock.h index 1645264890c4..f47bf73b7590 100644 --- a/src/v/model/timeout_clock.h +++ b/src/v/model/timeout_clock.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/timestamp.h b/src/v/model/timestamp.h index 31428aa751c9..00ba239cbd82 100644 --- a/src/v/model/timestamp.h +++ b/src/v/model/timestamp.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/model/validation.cc b/src/v/model/validation.cc index 36f075fa9c1e..1a761adbb343 100644 --- a/src/v/model/validation.cc +++ b/src/v/model/validation.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/model/validation.h b/src/v/model/validation.h index ea0ad444117c..1daffc92fdbd 100644 --- a/src/v/model/validation.h +++ b/src/v/model/validation.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/batched_output_stream.cc b/src/v/net/batched_output_stream.cc index 88a9ff0403fa..45b3afd57cbb 100644 --- a/src/v/net/batched_output_stream.cc +++ b/src/v/net/batched_output_stream.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/batched_output_stream.h b/src/v/net/batched_output_stream.h index 8434cd2a1a9c..6a428836b1c4 100644 --- a/src/v/net/batched_output_stream.h +++ b/src/v/net/batched_output_stream.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/client_probe.h b/src/v/net/client_probe.h index 514b666be727..b0626fc0b5e9 100644 --- a/src/v/net/client_probe.h +++ b/src/v/net/client_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/connection.cc b/src/v/net/connection.cc index db794cc9971f..20d41c4d4a47 100644 --- a/src/v/net/connection.cc +++ b/src/v/net/connection.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/connection.h b/src/v/net/connection.h index b6bb72be5187..611059966e1c 100644 --- a/src/v/net/connection.h +++ b/src/v/net/connection.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/dns.cc b/src/v/net/dns.cc index 2d397dae53c9..c965965cc898 100644 --- a/src/v/net/dns.cc +++ b/src/v/net/dns.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/dns.h b/src/v/net/dns.h index 6e9ec9a8801e..71457350edfb 100644 --- a/src/v/net/dns.h +++ b/src/v/net/dns.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/probes.cc b/src/v/net/probes.cc index a0a7acf6e72b..0a749075501e 100644 --- a/src/v/net/probes.cc +++ b/src/v/net/probes.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/server.cc b/src/v/net/server.cc index b3b67016dd90..13ce9babc9af 100644 --- a/src/v/net/server.cc +++ b/src/v/net/server.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/server.h b/src/v/net/server.h index 9396adc2a197..114bd834194f 100644 --- a/src/v/net/server.h +++ b/src/v/net/server.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/server_probe.h b/src/v/net/server_probe.h index c3319c2cad0b..0e380e56b9a8 100644 --- a/src/v/net/server_probe.h +++ b/src/v/net/server_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/unresolved_address.h b/src/v/net/unresolved_address.h index 579c481020a4..6e1a482923af 100644 --- a/src/v/net/unresolved_address.h +++ b/src/v/net/unresolved_address.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/oncore.h b/src/v/oncore.h index f70b1632051f..b5f48b2e718f 100644 --- a/src/v/oncore.h +++ b/src/v/oncore.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/outcome.h b/src/v/outcome.h index e07bd2ab65c6..5dd9bb8d02dd 100644 --- a/src/v/outcome.h +++ b/src/v/outcome.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/outcome_future_utils.h b/src/v/outcome_future_utils.h index 7f6416227b47..699b37d5e1c9 100644 --- a/src/v/outcome_future_utils.h +++ b/src/v/outcome_future_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/outcome_tests.cc b/src/v/outcome_tests.cc index 6940cbd41fcd..bb361a42bcc4 100644 --- a/src/v/outcome_tests.cc +++ b/src/v/outcome_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/iobuf.h b/src/v/pandaproxy/json/iobuf.h index f3b3496e7045..79ec11e176b6 100644 --- a/src/v/pandaproxy/json/iobuf.h +++ b/src/v/pandaproxy/json/iobuf.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/create_consumer.h b/src/v/pandaproxy/json/requests/create_consumer.h index b0cc96d6ad1c..4fd1ebf1c7e9 100644 --- a/src/v/pandaproxy/json/requests/create_consumer.h +++ b/src/v/pandaproxy/json/requests/create_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/error_reply.h b/src/v/pandaproxy/json/requests/error_reply.h index 9a9649c59433..c8770dcb500b 100644 --- a/src/v/pandaproxy/json/requests/error_reply.h +++ b/src/v/pandaproxy/json/requests/error_reply.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/fetch.h b/src/v/pandaproxy/json/requests/fetch.h index eb17a4bd3266..0eeaed4c0f26 100644 --- a/src/v/pandaproxy/json/requests/fetch.h +++ b/src/v/pandaproxy/json/requests/fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/offset_commit.h b/src/v/pandaproxy/json/requests/offset_commit.h index eb99a765b44e..c66db99e0392 100644 --- a/src/v/pandaproxy/json/requests/offset_commit.h +++ b/src/v/pandaproxy/json/requests/offset_commit.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/offset_fetch.h b/src/v/pandaproxy/json/requests/offset_fetch.h index aefc953ebb14..a804319e4e89 100644 --- a/src/v/pandaproxy/json/requests/offset_fetch.h +++ b/src/v/pandaproxy/json/requests/offset_fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/partition_offsets.h b/src/v/pandaproxy/json/requests/partition_offsets.h index 683e71adcaf3..a848d68f616b 100644 --- a/src/v/pandaproxy/json/requests/partition_offsets.h +++ b/src/v/pandaproxy/json/requests/partition_offsets.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/partitions.h b/src/v/pandaproxy/json/requests/partitions.h index 03c04c6df2e7..19f129e33a8b 100644 --- a/src/v/pandaproxy/json/requests/partitions.h +++ b/src/v/pandaproxy/json/requests/partitions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/produce.h b/src/v/pandaproxy/json/requests/produce.h index be5ddcb5777f..0ebecaec4b79 100644 --- a/src/v/pandaproxy/json/requests/produce.h +++ b/src/v/pandaproxy/json/requests/produce.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/subscribe_consumer.h b/src/v/pandaproxy/json/requests/subscribe_consumer.h index d3527d38de81..9e4a2cb458b3 100644 --- a/src/v/pandaproxy/json/requests/subscribe_consumer.h +++ b/src/v/pandaproxy/json/requests/subscribe_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/test/fetch.cc b/src/v/pandaproxy/json/requests/test/fetch.cc index 9f9e712edd74..e53c89d62127 100644 --- a/src/v/pandaproxy/json/requests/test/fetch.cc +++ b/src/v/pandaproxy/json/requests/test/fetch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/test/produce.cc b/src/v/pandaproxy/json/requests/test/produce.cc index b96af5de7a27..53d9b8ebae38 100644 --- a/src/v/pandaproxy/json/requests/test/produce.cc +++ b/src/v/pandaproxy/json/requests/test/produce.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/rjson_util.h b/src/v/pandaproxy/json/rjson_util.h index 9929372dd91a..d1d01ae70b36 100644 --- a/src/v/pandaproxy/json/rjson_util.h +++ b/src/v/pandaproxy/json/rjson_util.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/test/iobuf.cc b/src/v/pandaproxy/json/test/iobuf.cc index 7c7e00d4a108..8713238b3365 100644 --- a/src/v/pandaproxy/json/test/iobuf.cc +++ b/src/v/pandaproxy/json/test/iobuf.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/types.h b/src/v/pandaproxy/json/types.h index 57bb8e02b796..d698bcef6562 100644 --- a/src/v/pandaproxy/json/types.h +++ b/src/v/pandaproxy/json/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/logger.cc b/src/v/pandaproxy/logger.cc index 3d4c8f9fef40..068e18d8dda9 100644 --- a/src/v/pandaproxy/logger.cc +++ b/src/v/pandaproxy/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/logger.h b/src/v/pandaproxy/logger.h index c4dd665f6418..f8c420fec728 100644 --- a/src/v/pandaproxy/logger.h +++ b/src/v/pandaproxy/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/probe.cc b/src/v/pandaproxy/probe.cc index ad4a139f5f04..981f335df724 100644 --- a/src/v/pandaproxy/probe.cc +++ b/src/v/pandaproxy/probe.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/probe.h b/src/v/pandaproxy/probe.h index 65da51ccebe6..198a4036ffc4 100644 --- a/src/v/pandaproxy/probe.h +++ b/src/v/pandaproxy/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/reply.h b/src/v/pandaproxy/reply.h index dbb762efecb1..adbb926f752d 100644 --- a/src/v/pandaproxy/reply.h +++ b/src/v/pandaproxy/reply.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/configuration.cc b/src/v/pandaproxy/rest/configuration.cc index 72aca1e4b04b..977479c0f366 100644 --- a/src/v/pandaproxy/rest/configuration.cc +++ b/src/v/pandaproxy/rest/configuration.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/configuration.h b/src/v/pandaproxy/rest/configuration.h index f40895ad794e..1963c9154f1f 100644 --- a/src/v/pandaproxy/rest/configuration.h +++ b/src/v/pandaproxy/rest/configuration.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/fwd.h b/src/v/pandaproxy/rest/fwd.h index a6eaedb8808d..672452ce57a5 100644 --- a/src/v/pandaproxy/rest/fwd.h +++ b/src/v/pandaproxy/rest/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/handlers.cc b/src/v/pandaproxy/rest/handlers.cc index 7ccdd1db92fb..d3b5dc4be0e2 100644 --- a/src/v/pandaproxy/rest/handlers.cc +++ b/src/v/pandaproxy/rest/handlers.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/handlers.h b/src/v/pandaproxy/rest/handlers.h index 8d507b04bf3c..4b6c18e8075a 100644 --- a/src/v/pandaproxy/rest/handlers.h +++ b/src/v/pandaproxy/rest/handlers.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/proxy.cc b/src/v/pandaproxy/rest/proxy.cc index 616070e8b68b..d277e91d506c 100644 --- a/src/v/pandaproxy/rest/proxy.cc +++ b/src/v/pandaproxy/rest/proxy.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/proxy.h b/src/v/pandaproxy/rest/proxy.h index 89df30bf1c45..5560c6da0f4f 100644 --- a/src/v/pandaproxy/rest/proxy.h +++ b/src/v/pandaproxy/rest/proxy.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/test/consumer_group.cc b/src/v/pandaproxy/rest/test/consumer_group.cc index a37a43e0d475..c93abdb95549 100644 --- a/src/v/pandaproxy/rest/test/consumer_group.cc +++ b/src/v/pandaproxy/rest/test/consumer_group.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/test/fetch.cc b/src/v/pandaproxy/rest/test/fetch.cc index d9c25d0c9730..74a9d1afc856 100644 --- a/src/v/pandaproxy/rest/test/fetch.cc +++ b/src/v/pandaproxy/rest/test/fetch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/test/list_topics.cc b/src/v/pandaproxy/rest/test/list_topics.cc index 39e574b1f861..df6f7bf5d5ee 100644 --- a/src/v/pandaproxy/rest/test/list_topics.cc +++ b/src/v/pandaproxy/rest/test/list_topics.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/rest/test/produce.cc b/src/v/pandaproxy/rest/test/produce.cc index ff2f7052e45d..0e2c431f2482 100644 --- a/src/v/pandaproxy/rest/test/produce.cc +++ b/src/v/pandaproxy/rest/test/produce.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/consume_to_store.cc b/src/v/pandaproxy/schema_registry/test/consume_to_store.cc index 299932c885e1..2fd51685a092 100644 --- a/src/v/pandaproxy/schema_registry/test/consume_to_store.cc +++ b/src/v/pandaproxy/schema_registry/test/consume_to_store.cc @@ -7,7 +7,7 @@ // the Business Source License, use of this software will be governed // by the Apache License, Version 2.0 -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/delete_subject_endpoints.cc b/src/v/pandaproxy/schema_registry/test/delete_subject_endpoints.cc index 2a800c7f1440..c98eb0a3ca17 100644 --- a/src/v/pandaproxy/schema_registry/test/delete_subject_endpoints.cc +++ b/src/v/pandaproxy/schema_registry/test/delete_subject_endpoints.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/get_schema_types.cc b/src/v/pandaproxy/schema_registry/test/get_schema_types.cc index 3da8bd115442..783c8299f1cf 100644 --- a/src/v/pandaproxy/schema_registry/test/get_schema_types.cc +++ b/src/v/pandaproxy/schema_registry/test/get_schema_types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/one_shot.cc b/src/v/pandaproxy/schema_registry/test/one_shot.cc index 1a364106d84f..ec8a4d61a6e4 100644 --- a/src/v/pandaproxy/schema_registry/test/one_shot.cc +++ b/src/v/pandaproxy/schema_registry/test/one_shot.cc @@ -7,7 +7,7 @@ // the Business Source License, use of this software will be governed // by the Apache License, Version 2.0 -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/post_subjects_subject_version.cc b/src/v/pandaproxy/schema_registry/test/post_subjects_subject_version.cc index 96bd50e0ee55..b590773eaaf3 100644 --- a/src/v/pandaproxy/schema_registry/test/post_subjects_subject_version.cc +++ b/src/v/pandaproxy/schema_registry/test/post_subjects_subject_version.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/server.cc b/src/v/pandaproxy/server.cc index b631ad39b0c6..1154864dba30 100644 --- a/src/v/pandaproxy/server.cc +++ b/src/v/pandaproxy/server.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/server.h b/src/v/pandaproxy/server.h index d94ab0cf6273..344d7b9f3032 100644 --- a/src/v/pandaproxy/server.h +++ b/src/v/pandaproxy/server.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/test/pandaproxy_fixture.h b/src/v/pandaproxy/test/pandaproxy_fixture.h index 6746aef6d7da..55d336033ac2 100644 --- a/src/v/pandaproxy/test/pandaproxy_fixture.h +++ b/src/v/pandaproxy/test/pandaproxy_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/test/utils.h b/src/v/pandaproxy/test/utils.h index f396f38e36fe..41302e5f010b 100644 --- a/src/v/pandaproxy/test/utils.h +++ b/src/v/pandaproxy/test/utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/platform/stop_signal.h b/src/v/platform/stop_signal.h index 721368518133..e823f6978ae6 100644 --- a/src/v/platform/stop_signal.h +++ b/src/v/platform/stop_signal.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/prometheus/prometheus_sanitize.h b/src/v/prometheus/prometheus_sanitize.h index 6a8f78921aa3..dfa6c6c20dc3 100644 --- a/src/v/prometheus/prometheus_sanitize.h +++ b/src/v/prometheus/prometheus_sanitize.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/configuration_bootstrap_state.cc b/src/v/raft/configuration_bootstrap_state.cc index b56fb168d4ad..469eba65c9d2 100644 --- a/src/v/raft/configuration_bootstrap_state.cc +++ b/src/v/raft/configuration_bootstrap_state.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/configuration_bootstrap_state.h b/src/v/raft/configuration_bootstrap_state.h index 30a62b80bc32..1fa7ffdc0270 100644 --- a/src/v/raft/configuration_bootstrap_state.h +++ b/src/v/raft/configuration_bootstrap_state.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/configuration_manager.cc b/src/v/raft/configuration_manager.cc index cc9f868be6f5..e7ad9f719ae7 100644 --- a/src/v/raft/configuration_manager.cc +++ b/src/v/raft/configuration_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/configuration_manager.h b/src/v/raft/configuration_manager.h index 2f8983561b84..a04ca344e876 100644 --- a/src/v/raft/configuration_manager.h +++ b/src/v/raft/configuration_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/consensus.cc b/src/v/raft/consensus.cc index cc81cc8ff6f4..d98aa562a11d 100644 --- a/src/v/raft/consensus.cc +++ b/src/v/raft/consensus.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/consensus.h b/src/v/raft/consensus.h index 55d58ad49ff7..4a084165b04d 100644 --- a/src/v/raft/consensus.h +++ b/src/v/raft/consensus.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/consensus_client_protocol.h b/src/v/raft/consensus_client_protocol.h index 08c811dfbf89..ad5f9ea8f491 100644 --- a/src/v/raft/consensus_client_protocol.h +++ b/src/v/raft/consensus_client_protocol.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/consensus_utils.cc b/src/v/raft/consensus_utils.cc index 958cea23fcfe..c01ea4c7f784 100644 --- a/src/v/raft/consensus_utils.cc +++ b/src/v/raft/consensus_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/consensus_utils.h b/src/v/raft/consensus_utils.h index 1ce3be15f1ee..c6e2517684b6 100644 --- a/src/v/raft/consensus_utils.h +++ b/src/v/raft/consensus_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/errc.h b/src/v/raft/errc.h index 0498459427a9..92a6bdccece9 100644 --- a/src/v/raft/errc.h +++ b/src/v/raft/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/event_manager.cc b/src/v/raft/event_manager.cc index 44381a6507e2..f32089571f65 100644 --- a/src/v/raft/event_manager.cc +++ b/src/v/raft/event_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/event_manager.h b/src/v/raft/event_manager.h index 24590de098c6..9cdff60d9ec0 100644 --- a/src/v/raft/event_manager.h +++ b/src/v/raft/event_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/follower_queue.cc b/src/v/raft/follower_queue.cc index 99e0830dee17..48a6518f0ac5 100644 --- a/src/v/raft/follower_queue.cc +++ b/src/v/raft/follower_queue.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/follower_queue.h b/src/v/raft/follower_queue.h index 5e351951539a..92474117b5c6 100644 --- a/src/v/raft/follower_queue.h +++ b/src/v/raft/follower_queue.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/follower_stats.cc b/src/v/raft/follower_stats.cc index d1e87702e93b..75ddcaa17a3a 100644 --- a/src/v/raft/follower_stats.cc +++ b/src/v/raft/follower_stats.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/follower_stats.h b/src/v/raft/follower_stats.h index 55721f3811b9..c22e974154bc 100644 --- a/src/v/raft/follower_stats.h +++ b/src/v/raft/follower_stats.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/fwd.h b/src/v/raft/fwd.h index ca33a0290070..1b68b34da57f 100644 --- a/src/v/raft/fwd.h +++ b/src/v/raft/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/group_configuration.cc b/src/v/raft/group_configuration.cc index e65227ed31a0..8360437768b4 100644 --- a/src/v/raft/group_configuration.cc +++ b/src/v/raft/group_configuration.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/group_configuration.h b/src/v/raft/group_configuration.h index 5e02742d17ea..960c281ece45 100644 --- a/src/v/raft/group_configuration.h +++ b/src/v/raft/group_configuration.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/group_manager.cc b/src/v/raft/group_manager.cc index cf0acfd1ce38..446bb1c742f2 100644 --- a/src/v/raft/group_manager.cc +++ b/src/v/raft/group_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/group_manager.h b/src/v/raft/group_manager.h index c94335d16b7c..eba18c7412b7 100644 --- a/src/v/raft/group_manager.h +++ b/src/v/raft/group_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/heartbeat_manager.cc b/src/v/raft/heartbeat_manager.cc index 79a2209f8b25..93e26049e4bb 100644 --- a/src/v/raft/heartbeat_manager.cc +++ b/src/v/raft/heartbeat_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/heartbeat_manager.h b/src/v/raft/heartbeat_manager.h index a053aecd3f0c..ba4e115daf63 100644 --- a/src/v/raft/heartbeat_manager.h +++ b/src/v/raft/heartbeat_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/errc.h b/src/v/raft/kvelldb/errc.h index 13534a2d00f8..82548798894d 100644 --- a/src/v/raft/kvelldb/errc.h +++ b/src/v/raft/kvelldb/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/httpkvrsm.cc b/src/v/raft/kvelldb/httpkvrsm.cc index 3ae787a52686..f31a73277284 100644 --- a/src/v/raft/kvelldb/httpkvrsm.cc +++ b/src/v/raft/kvelldb/httpkvrsm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/httpkvrsm.h b/src/v/raft/kvelldb/httpkvrsm.h index b2406126fa19..75abbf8e3812 100644 --- a/src/v/raft/kvelldb/httpkvrsm.h +++ b/src/v/raft/kvelldb/httpkvrsm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/kvrsm.cc b/src/v/raft/kvelldb/kvrsm.cc index 6200fcbfd9cf..71d9b31a3e1c 100644 --- a/src/v/raft/kvelldb/kvrsm.cc +++ b/src/v/raft/kvelldb/kvrsm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/kvrsm.h b/src/v/raft/kvelldb/kvrsm.h index 3a4b8921d71a..dc238c1d3108 100644 --- a/src/v/raft/kvelldb/kvrsm.h +++ b/src/v/raft/kvelldb/kvrsm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/kvserver.cc b/src/v/raft/kvelldb/kvserver.cc index b945c798fae4..12393024890f 100644 --- a/src/v/raft/kvelldb/kvserver.cc +++ b/src/v/raft/kvelldb/kvserver.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/logger.cc b/src/v/raft/kvelldb/logger.cc index 8b40c39b089e..b60a7d11c3a3 100644 --- a/src/v/raft/kvelldb/logger.cc +++ b/src/v/raft/kvelldb/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/kvelldb/logger.h b/src/v/raft/kvelldb/logger.h index 1abb992ff3bf..f63a0cf8a112 100644 --- a/src/v/raft/kvelldb/logger.h +++ b/src/v/raft/kvelldb/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/log_eviction_stm.cc b/src/v/raft/log_eviction_stm.cc index 5e6c59573621..16061c17558f 100644 --- a/src/v/raft/log_eviction_stm.cc +++ b/src/v/raft/log_eviction_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/log_eviction_stm.h b/src/v/raft/log_eviction_stm.h index d4252bb6c398..9d27ade68d38 100644 --- a/src/v/raft/log_eviction_stm.h +++ b/src/v/raft/log_eviction_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/logger.cc b/src/v/raft/logger.cc index 8529e9b88cbf..b1c690cfdbad 100644 --- a/src/v/raft/logger.cc +++ b/src/v/raft/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/logger.h b/src/v/raft/logger.h index 901603a15985..cdb45e4d5c3c 100644 --- a/src/v/raft/logger.h +++ b/src/v/raft/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/mux_state_machine.h b/src/v/raft/mux_state_machine.h index 3ad520e79304..fc236ee03141 100644 --- a/src/v/raft/mux_state_machine.h +++ b/src/v/raft/mux_state_machine.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/offset_monitor.cc b/src/v/raft/offset_monitor.cc index fee1161f51c7..a026b1e98196 100644 --- a/src/v/raft/offset_monitor.cc +++ b/src/v/raft/offset_monitor.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/offset_monitor.h b/src/v/raft/offset_monitor.h index 706e67fe480b..74acea2bacd0 100644 --- a/src/v/raft/offset_monitor.h +++ b/src/v/raft/offset_monitor.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/prevote_stm.cc b/src/v/raft/prevote_stm.cc index 896c34dea253..07afb9ede039 100644 --- a/src/v/raft/prevote_stm.cc +++ b/src/v/raft/prevote_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/prevote_stm.h b/src/v/raft/prevote_stm.h index 3abc2ad1dc9f..dcad0caede24 100644 --- a/src/v/raft/prevote_stm.h +++ b/src/v/raft/prevote_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/probe.cc b/src/v/raft/probe.cc index e5b4a9848e74..f8fa016b6035 100644 --- a/src/v/raft/probe.cc +++ b/src/v/raft/probe.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/probe.h b/src/v/raft/probe.h index 56b2bb420c85..f8b5b78ed324 100644 --- a/src/v/raft/probe.h +++ b/src/v/raft/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/recovery_memory_quota.cc b/src/v/raft/recovery_memory_quota.cc index 875b588473e6..e90034febd03 100644 --- a/src/v/raft/recovery_memory_quota.cc +++ b/src/v/raft/recovery_memory_quota.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/recovery_memory_quota.h b/src/v/raft/recovery_memory_quota.h index 2f6263d3e20b..e59ca95d5b87 100644 --- a/src/v/raft/recovery_memory_quota.h +++ b/src/v/raft/recovery_memory_quota.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/recovery_stm.cc b/src/v/raft/recovery_stm.cc index 8653b56a034b..a3b1f0e3490a 100644 --- a/src/v/raft/recovery_stm.cc +++ b/src/v/raft/recovery_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/recovery_stm.h b/src/v/raft/recovery_stm.h index e5c8f45a72c6..3b275596e3f0 100644 --- a/src/v/raft/recovery_stm.h +++ b/src/v/raft/recovery_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/recovery_throttle.h b/src/v/raft/recovery_throttle.h index 2a11e1a65ca5..eef84a5d070d 100644 --- a/src/v/raft/recovery_throttle.h +++ b/src/v/raft/recovery_throttle.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/replicate_batcher.cc b/src/v/raft/replicate_batcher.cc index 0128a3149a17..5fb61c0f1aeb 100644 --- a/src/v/raft/replicate_batcher.cc +++ b/src/v/raft/replicate_batcher.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/replicate_batcher.h b/src/v/raft/replicate_batcher.h index 69ed5099f131..d583bf91754b 100644 --- a/src/v/raft/replicate_batcher.h +++ b/src/v/raft/replicate_batcher.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/replicate_entries_stm.cc b/src/v/raft/replicate_entries_stm.cc index 599c4f3fcd90..a3bf3cf5efea 100644 --- a/src/v/raft/replicate_entries_stm.cc +++ b/src/v/raft/replicate_entries_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/replicate_entries_stm.h b/src/v/raft/replicate_entries_stm.h index cdf22535492f..505244e23a5a 100644 --- a/src/v/raft/replicate_entries_stm.h +++ b/src/v/raft/replicate_entries_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/rpc_client_protocol.cc b/src/v/raft/rpc_client_protocol.cc index 2c963d4b64c5..d3e16abe8a16 100644 --- a/src/v/raft/rpc_client_protocol.cc +++ b/src/v/raft/rpc_client_protocol.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/rpc_client_protocol.h b/src/v/raft/rpc_client_protocol.h index c932cc4f962b..0e7dff7b5772 100644 --- a/src/v/raft/rpc_client_protocol.h +++ b/src/v/raft/rpc_client_protocol.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/service.h b/src/v/raft/service.h index 70678fa079a2..1c8c59869663 100644 --- a/src/v/raft/service.h +++ b/src/v/raft/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/state_machine.cc b/src/v/raft/state_machine.cc index 10d2a2ba5f11..eec34fd6d42a 100644 --- a/src/v/raft/state_machine.cc +++ b/src/v/raft/state_machine.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/state_machine.h b/src/v/raft/state_machine.h index 25af8957eec4..d93130596c76 100644 --- a/src/v/raft/state_machine.h +++ b/src/v/raft/state_machine.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tests/append_entries_test.cc b/src/v/raft/tests/append_entries_test.cc index 5761d9db6bee..a4bbb5bab422 100644 --- a/src/v/raft/tests/append_entries_test.cc +++ b/src/v/raft/tests/append_entries_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/bootstrap_configuration_test.cc b/src/v/raft/tests/bootstrap_configuration_test.cc index 235049fdd7d5..8382fb54d100 100644 --- a/src/v/raft/tests/bootstrap_configuration_test.cc +++ b/src/v/raft/tests/bootstrap_configuration_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/configuration_manager_test.cc b/src/v/raft/tests/configuration_manager_test.cc index aa93952a2d15..4822f4bb5096 100644 --- a/src/v/raft/tests/configuration_manager_test.cc +++ b/src/v/raft/tests/configuration_manager_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/configuration_serialization_test.cc b/src/v/raft/tests/configuration_serialization_test.cc index 33704a7f8a46..21c610d77075 100644 --- a/src/v/raft/tests/configuration_serialization_test.cc +++ b/src/v/raft/tests/configuration_serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/consensus_utils_test.cc b/src/v/raft/tests/consensus_utils_test.cc index 8b90ade33976..c42bde968b7c 100644 --- a/src/v/raft/tests/consensus_utils_test.cc +++ b/src/v/raft/tests/consensus_utils_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/foreign_entry_test.cc b/src/v/raft/tests/foreign_entry_test.cc index a614a8d4bd90..0edc87a3d972 100644 --- a/src/v/raft/tests/foreign_entry_test.cc +++ b/src/v/raft/tests/foreign_entry_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/group_configuration_tests.cc b/src/v/raft/tests/group_configuration_tests.cc index a1ca677d233f..1ec58b48d316 100644 --- a/src/v/raft/tests/group_configuration_tests.cc +++ b/src/v/raft/tests/group_configuration_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/jitter_tests.cc b/src/v/raft/tests/jitter_tests.cc index 500ea713195f..74d93775e8b1 100644 --- a/src/v/raft/tests/jitter_tests.cc +++ b/src/v/raft/tests/jitter_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/leadership_test.cc b/src/v/raft/tests/leadership_test.cc index d1532460748e..cf5c51fc629b 100644 --- a/src/v/raft/tests/leadership_test.cc +++ b/src/v/raft/tests/leadership_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/manual_log_deletion_test.cc b/src/v/raft/tests/manual_log_deletion_test.cc index 2e20751c346d..fa9747901631 100644 --- a/src/v/raft/tests/manual_log_deletion_test.cc +++ b/src/v/raft/tests/manual_log_deletion_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/membership_test.cc b/src/v/raft/tests/membership_test.cc index aa1438933f9a..fd08e2dbfd40 100644 --- a/src/v/raft/tests/membership_test.cc +++ b/src/v/raft/tests/membership_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/mux_state_machine_fixture.h b/src/v/raft/tests/mux_state_machine_fixture.h index 8ca44a253767..5d946f3673f3 100644 --- a/src/v/raft/tests/mux_state_machine_fixture.h +++ b/src/v/raft/tests/mux_state_machine_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tests/mux_state_machine_test.cc b/src/v/raft/tests/mux_state_machine_test.cc index eaa6e9a7bf70..2746ca25d436 100644 --- a/src/v/raft/tests/mux_state_machine_test.cc +++ b/src/v/raft/tests/mux_state_machine_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/offset_monitor_test.cc b/src/v/raft/tests/offset_monitor_test.cc index 89905945a4c8..e3b878417645 100644 --- a/src/v/raft/tests/offset_monitor_test.cc +++ b/src/v/raft/tests/offset_monitor_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/offset_translator_tests.cc b/src/v/raft/tests/offset_translator_tests.cc index a540f4880f1a..492080b3f31d 100644 --- a/src/v/raft/tests/offset_translator_tests.cc +++ b/src/v/raft/tests/offset_translator_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/raft_group_fixture.h b/src/v/raft/tests/raft_group_fixture.h index 4c354c104a00..ecc36a0dbc6b 100644 --- a/src/v/raft/tests/raft_group_fixture.h +++ b/src/v/raft/tests/raft_group_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tests/simple_record_fixture.h b/src/v/raft/tests/simple_record_fixture.h index 2ef8634c6c04..2d2cb6fae28a 100644 --- a/src/v/raft/tests/simple_record_fixture.h +++ b/src/v/raft/tests/simple_record_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tests/state_removal_test.cc b/src/v/raft/tests/state_removal_test.cc index d8e65e9c61e0..d489f55b5257 100644 --- a/src/v/raft/tests/state_removal_test.cc +++ b/src/v/raft/tests/state_removal_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/term_assigning_reader_test.cc b/src/v/raft/tests/term_assigning_reader_test.cc index bab2fd45fcc9..1145cd182460 100644 --- a/src/v/raft/tests/term_assigning_reader_test.cc +++ b/src/v/raft/tests/term_assigning_reader_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tests/type_serialization_tests.cc b/src/v/raft/tests/type_serialization_tests.cc index 37719950d367..3ed9f26fda7d 100644 --- a/src/v/raft/tests/type_serialization_tests.cc +++ b/src/v/raft/tests/type_serialization_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/timeout_jitter.h b/src/v/raft/timeout_jitter.h index 645fffbcf07e..896b15546beb 100644 --- a/src/v/raft/timeout_jitter.h +++ b/src/v/raft/timeout_jitter.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tron/client.cc b/src/v/raft/tron/client.cc index c5b6095a4752..ff15e13a2acc 100644 --- a/src/v/raft/tron/client.cc +++ b/src/v/raft/tron/client.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tron/logger.cc b/src/v/raft/tron/logger.cc index b53df0b0d44b..ad1f8056f244 100644 --- a/src/v/raft/tron/logger.cc +++ b/src/v/raft/tron/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tron/logger.h b/src/v/raft/tron/logger.h index aa2812223c6d..7e9b0598e3d2 100644 --- a/src/v/raft/tron/logger.h +++ b/src/v/raft/tron/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tron/server.cc b/src/v/raft/tron/server.cc index d1cc1bbb58b3..6f87eeada058 100644 --- a/src/v/raft/tron/server.cc +++ b/src/v/raft/tron/server.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/tron/service.h b/src/v/raft/tron/service.h index 4e0992f8ced1..581556b21ec0 100644 --- a/src/v/raft/tron/service.h +++ b/src/v/raft/tron/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/tron/types.h b/src/v/raft/tron/types.h index e3c870d8dfba..09a2a2166ae4 100644 --- a/src/v/raft/tron/types.h +++ b/src/v/raft/tron/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/types.cc b/src/v/raft/types.cc index 484850cbede5..daefd7aa467d 100644 --- a/src/v/raft/types.cc +++ b/src/v/raft/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/types.h b/src/v/raft/types.h index 4b5566c82020..58d33e4b5cb4 100644 --- a/src/v/raft/types.h +++ b/src/v/raft/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/vote_stm.cc b/src/v/raft/vote_stm.cc index 8c6511fc7e30..4fb0906d76bd 100644 --- a/src/v/raft/vote_stm.cc +++ b/src/v/raft/vote_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/raft/vote_stm.h b/src/v/raft/vote_stm.h index 01272378120a..42d7a492851f 100644 --- a/src/v/raft/vote_stm.h +++ b/src/v/raft/vote_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/random/fast_prng.h b/src/v/random/fast_prng.h index 22133433714b..fa095f9c7f02 100644 --- a/src/v/random/fast_prng.h +++ b/src/v/random/fast_prng.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/random/generators.h b/src/v/random/generators.h index ff326f645567..2c910b9729f3 100644 --- a/src/v/random/generators.h +++ b/src/v/random/generators.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/random/random_test.cc b/src/v/random/random_test.cc index ae5fc1e8cdbe..bf0469074378 100644 --- a/src/v/random/random_test.cc +++ b/src/v/random/random_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/random/simple_time_jitter.h b/src/v/random/simple_time_jitter.h index 4d521b60290d..387411eab21f 100644 --- a/src/v/random/simple_time_jitter.h +++ b/src/v/random/simple_time_jitter.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/redpanda/admin_server.cc b/src/v/redpanda/admin_server.cc index 0598ca867e2f..27d46e0916a1 100644 --- a/src/v/redpanda/admin_server.cc +++ b/src/v/redpanda/admin_server.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/redpanda/admin_server.h b/src/v/redpanda/admin_server.h index 631580cffdb7..28ef51bf8d8f 100644 --- a/src/v/redpanda/admin_server.h +++ b/src/v/redpanda/admin_server.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/redpanda/application.cc b/src/v/redpanda/application.cc index 1e7d518e2ec3..b03a7d06c132 100644 --- a/src/v/redpanda/application.cc +++ b/src/v/redpanda/application.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/redpanda/application.h b/src/v/redpanda/application.h index 3e5f7e5dba1c..b7ae8f226d89 100644 --- a/src/v/redpanda/application.h +++ b/src/v/redpanda/application.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/redpanda/main.cc b/src/v/redpanda/main.cc index 1be28d10a761..cf436006ceb0 100644 --- a/src/v/redpanda/main.cc +++ b/src/v/redpanda/main.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/redpanda/tests/fixture.h b/src/v/redpanda/tests/fixture.h index 1516e6f4ca9b..a690dc9f7c49 100644 --- a/src/v/redpanda/tests/fixture.h +++ b/src/v/redpanda/tests/fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/adl.h b/src/v/reflection/adl.h index 15116bee65c5..56f39c43d4f1 100644 --- a/src/v/reflection/adl.h +++ b/src/v/reflection/adl.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/arity.h b/src/v/reflection/arity.h index 69dfa8b16990..5ebe723af344 100644 --- a/src/v/reflection/arity.h +++ b/src/v/reflection/arity.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/async_adl.h b/src/v/reflection/async_adl.h index a69a55b28d0d..a015b11a896d 100644 --- a/src/v/reflection/async_adl.h +++ b/src/v/reflection/async_adl.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/for_each_field.h b/src/v/reflection/for_each_field.h index 2b76de7303a9..6731f6272cd5 100644 --- a/src/v/reflection/for_each_field.h +++ b/src/v/reflection/for_each_field.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/test/arity_test.cc b/src/v/reflection/test/arity_test.cc index 3b7b218827ca..ffb51402fd10 100644 --- a/src/v/reflection/test/arity_test.cc +++ b/src/v/reflection/test/arity_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/reflection/test/async_adl_test.cc b/src/v/reflection/test/async_adl_test.cc index f29d8fb31640..95e406d7de3e 100644 --- a/src/v/reflection/test/async_adl_test.cc +++ b/src/v/reflection/test/async_adl_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/reflection/to_tuple.h b/src/v/reflection/to_tuple.h index c34f2aa07ea3..175e4b0cb4ec 100644 --- a/src/v/reflection/to_tuple.h +++ b/src/v/reflection/to_tuple.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/type_traits.h b/src/v/reflection/type_traits.h index e04f25797098..a9d8ba94630f 100644 --- a/src/v/reflection/type_traits.h +++ b/src/v/reflection/type_traits.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/resource_mgmt/cpu_scheduling.h b/src/v/resource_mgmt/cpu_scheduling.h index 8fc7c09cc8b7..0d07761e068f 100644 --- a/src/v/resource_mgmt/cpu_scheduling.h +++ b/src/v/resource_mgmt/cpu_scheduling.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/resource_mgmt/io_priority.h b/src/v/resource_mgmt/io_priority.h index 32c7f3d44a09..adf23736a2bb 100644 --- a/src/v/resource_mgmt/io_priority.h +++ b/src/v/resource_mgmt/io_priority.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/resource_mgmt/memory_groups.h b/src/v/resource_mgmt/memory_groups.h index ce008b3ab10a..4e2dccefe274 100644 --- a/src/v/resource_mgmt/memory_groups.h +++ b/src/v/resource_mgmt/memory_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/resource_mgmt/rate.h b/src/v/resource_mgmt/rate.h index a4a4a281cdac..f81ea086db7f 100644 --- a/src/v/resource_mgmt/rate.h +++ b/src/v/resource_mgmt/rate.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/resource_mgmt/smp_groups.h b/src/v/resource_mgmt/smp_groups.h index cbbd864372e1..61d06cbe5570 100644 --- a/src/v/resource_mgmt/smp_groups.h +++ b/src/v/resource_mgmt/smp_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/backoff_policy.h b/src/v/rpc/backoff_policy.h index 73b62550707b..c90605e5f98f 100644 --- a/src/v/rpc/backoff_policy.h +++ b/src/v/rpc/backoff_policy.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/connection_cache.cc b/src/v/rpc/connection_cache.cc index 8fa45565ff92..16b06c552cc5 100644 --- a/src/v/rpc/connection_cache.cc +++ b/src/v/rpc/connection_cache.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/connection_cache.h b/src/v/rpc/connection_cache.h index b2120701eb51..aa3a8e037444 100644 --- a/src/v/rpc/connection_cache.h +++ b/src/v/rpc/connection_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/demo/client.cc b/src/v/rpc/demo/client.cc index 689ae93dada5..b34f6b3adc3d 100644 --- a/src/v/rpc/demo/client.cc +++ b/src/v/rpc/demo/client.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/demo/demo_utils.h b/src/v/rpc/demo/demo_utils.h index c3ce82eccfe7..b9d55409cdc9 100644 --- a/src/v/rpc/demo/demo_utils.h +++ b/src/v/rpc/demo/demo_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/demo/server.cc b/src/v/rpc/demo/server.cc index 2b7bfc68abf3..c30a94ff8a78 100644 --- a/src/v/rpc/demo/server.cc +++ b/src/v/rpc/demo/server.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/demo/type_tests.cc b/src/v/rpc/demo/type_tests.cc index b52f0df19f29..228559f39262 100644 --- a/src/v/rpc/demo/type_tests.cc +++ b/src/v/rpc/demo/type_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/demo/types.h b/src/v/rpc/demo/types.h index 08844882cad9..66cf48d2786f 100644 --- a/src/v/rpc/demo/types.h +++ b/src/v/rpc/demo/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/errc.h b/src/v/rpc/errc.h index 42cc4824f5d8..b58201dc0174 100644 --- a/src/v/rpc/errc.h +++ b/src/v/rpc/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/exceptions.h b/src/v/rpc/exceptions.h index cd1137510494..4302a20c8f10 100644 --- a/src/v/rpc/exceptions.h +++ b/src/v/rpc/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/logger.h b/src/v/rpc/logger.h index 240e159fb1af..edecf0d509df 100644 --- a/src/v/rpc/logger.h +++ b/src/v/rpc/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/netbuf.cc b/src/v/rpc/netbuf.cc index 4464198277af..b68e657e60f2 100644 --- a/src/v/rpc/netbuf.cc +++ b/src/v/rpc/netbuf.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/parse_utils.h b/src/v/rpc/parse_utils.h index 5310bd497eb6..ebd29393981a 100644 --- a/src/v/rpc/parse_utils.h +++ b/src/v/rpc/parse_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/reconnect_transport.cc b/src/v/rpc/reconnect_transport.cc index 9e69679f76a8..d6ed265fede7 100644 --- a/src/v/rpc/reconnect_transport.cc +++ b/src/v/rpc/reconnect_transport.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/reconnect_transport.h b/src/v/rpc/reconnect_transport.h index 0ccf23500b39..d44ff18908b4 100644 --- a/src/v/rpc/reconnect_transport.h +++ b/src/v/rpc/reconnect_transport.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/response_handler.h b/src/v/rpc/response_handler.h index 76e5d87caf1e..9635ef26744a 100644 --- a/src/v/rpc/response_handler.h +++ b/src/v/rpc/response_handler.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/service.h b/src/v/rpc/service.h index d384a5b1f9c0..f61bbb3a922b 100644 --- a/src/v/rpc/service.h +++ b/src/v/rpc/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/simple_protocol.cc b/src/v/rpc/simple_protocol.cc index 9decc8399e49..b969bc76b440 100644 --- a/src/v/rpc/simple_protocol.cc +++ b/src/v/rpc/simple_protocol.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/simple_protocol.h b/src/v/rpc/simple_protocol.h index db7b113efbaf..b1e1afdb3dba 100644 --- a/src/v/rpc/simple_protocol.h +++ b/src/v/rpc/simple_protocol.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/test/exponential_backoff.cc b/src/v/rpc/test/exponential_backoff.cc index e275eece8be6..365c13362d24 100644 --- a/src/v/rpc/test/exponential_backoff.cc +++ b/src/v/rpc/test/exponential_backoff.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/netbuf_tests.cc b/src/v/rpc/test/netbuf_tests.cc index 69ceddb5191c..3d8ac0112643 100644 --- a/src/v/rpc/test/netbuf_tests.cc +++ b/src/v/rpc/test/netbuf_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/response_handler_tests.cc b/src/v/rpc/test/response_handler_tests.cc index e3309235e37e..81d721ca46fb 100644 --- a/src/v/rpc/test/response_handler_tests.cc +++ b/src/v/rpc/test/response_handler_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/roundtrip_tests.cc b/src/v/rpc/test/roundtrip_tests.cc index 20962424078d..0f63c79e6d5b 100644 --- a/src/v/rpc/test/roundtrip_tests.cc +++ b/src/v/rpc/test/roundtrip_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/rpc_bench.cc b/src/v/rpc/test/rpc_bench.cc index 485cc0e5688f..cde9f603a428 100644 --- a/src/v/rpc/test/rpc_bench.cc +++ b/src/v/rpc/test/rpc_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/rpc_gen_cycling_test.cc b/src/v/rpc/test/rpc_gen_cycling_test.cc index 95c1df172b38..262e17c9122a 100644 --- a/src/v/rpc/test/rpc_gen_cycling_test.cc +++ b/src/v/rpc/test/rpc_gen_cycling_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/rpc_gen_types.h b/src/v/rpc/test/rpc_gen_types.h index 960c04364435..7527d8e9c2f8 100644 --- a/src/v/rpc/test/rpc_gen_types.h +++ b/src/v/rpc/test/rpc_gen_types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/test/rpc_integration_fixture.h b/src/v/rpc/test/rpc_integration_fixture.h index 2af5749f4335..465a6e3aade2 100644 --- a/src/v/rpc/test/rpc_integration_fixture.h +++ b/src/v/rpc/test/rpc_integration_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/test/serialization_test.cc b/src/v/rpc/test/serialization_test.cc index c7b9d8b94486..971b86ee2c1e 100644 --- a/src/v/rpc/test/serialization_test.cc +++ b/src/v/rpc/test/serialization_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/test/test_types.h b/src/v/rpc/test/test_types.h index 2653a5d53e19..a6e08af0ac29 100644 --- a/src/v/rpc/test/test_types.h +++ b/src/v/rpc/test/test_types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/transport.cc b/src/v/rpc/transport.cc index 73a18ee1bcdd..c314230a78bf 100644 --- a/src/v/rpc/transport.cc +++ b/src/v/rpc/transport.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/transport.h b/src/v/rpc/transport.h index 9fd9bbf6afbd..2a38878f68f5 100644 --- a/src/v/rpc/transport.h +++ b/src/v/rpc/transport.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/types.cc b/src/v/rpc/types.cc index 5b6c25f16d26..7f26c88d35a3 100644 --- a/src/v/rpc/types.cc +++ b/src/v/rpc/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/rpc/types.h b/src/v/rpc/types.h index b11c77273a7d..6c7a8354f96f 100644 --- a/src/v/rpc/types.h +++ b/src/v/rpc/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/s3/client.cc b/src/v/s3/client.cc index 1afc4f4471d1..72d44b27d887 100644 --- a/src/v/s3/client.cc +++ b/src/v/s3/client.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/client.h b/src/v/s3/client.h index 3caa46efca87..f5c8cace285e 100644 --- a/src/v/s3/client.h +++ b/src/v/s3/client.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/client_probe.cc b/src/v/s3/client_probe.cc index 94ac39fec2f5..0ad4ef3ddb15 100644 --- a/src/v/s3/client_probe.cc +++ b/src/v/s3/client_probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/client_probe.h b/src/v/s3/client_probe.h index 7a8fac283f9b..a424a18dad4d 100644 --- a/src/v/s3/client_probe.h +++ b/src/v/s3/client_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/error.cc b/src/v/s3/error.cc index d5c7402bbd5f..fcdc89b0e814 100644 --- a/src/v/s3/error.cc +++ b/src/v/s3/error.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/error.h b/src/v/s3/error.h index d5dba191a212..99c45e67937b 100644 --- a/src/v/s3/error.h +++ b/src/v/s3/error.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/logger.h b/src/v/s3/logger.h index 8037e501a781..16dd7e9ae8ad 100644 --- a/src/v/s3/logger.h +++ b/src/v/s3/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/signature.cc b/src/v/s3/signature.cc index af502a594630..c4136137c2d7 100644 --- a/src/v/s3/signature.cc +++ b/src/v/s3/signature.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/signature.h b/src/v/s3/signature.h index 68bf3b9a2ccc..00aff552350b 100644 --- a/src/v/s3/signature.h +++ b/src/v/s3/signature.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/test_client/s3_test_client_main.cc b/src/v/s3/test_client/s3_test_client_main.cc index 51d17e50ef9c..3a69d18d3463 100644 --- a/src/v/s3/test_client/s3_test_client_main.cc +++ b/src/v/s3/test_client/s3_test_client_main.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/tests/s3_client_test.cc b/src/v/s3/tests/s3_client_test.cc index da21681b0c62..3d611ccb2398 100644 --- a/src/v/s3/tests/s3_client_test.cc +++ b/src/v/s3/tests/s3_client_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/s3/tests/signature_test.cc b/src/v/s3/tests/signature_test.cc index b67ad957e233..8425b702c5e0 100644 --- a/src/v/s3/tests/signature_test.cc +++ b/src/v/s3/tests/signature_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/seastarx.h b/src/v/seastarx.h index cb6365d85cfa..9490f9304728 100644 --- a/src/v/seastarx.h +++ b/src/v/seastarx.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/credential_store.h b/src/v/security/credential_store.h index 7a59dfa86d16..1f039df98b9b 100644 --- a/src/v/security/credential_store.h +++ b/src/v/security/credential_store.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/errc.h b/src/v/security/errc.h index e58d7a11cb73..af7ef3e1645d 100644 --- a/src/v/security/errc.h +++ b/src/v/security/errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/logger.h b/src/v/security/logger.h index 84c460d0bb69..63bd7601b1de 100644 --- a/src/v/security/logger.h +++ b/src/v/security/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/sasl_authentication.h b/src/v/security/sasl_authentication.h index bfba633d8e34..1cd908634f02 100644 --- a/src/v/security/sasl_authentication.h +++ b/src/v/security/sasl_authentication.h @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/security/scram_algorithm.h b/src/v/security/scram_algorithm.h index 6d63cb86a8cd..dec650b0c50c 100644 --- a/src/v/security/scram_algorithm.h +++ b/src/v/security/scram_algorithm.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/scram_authenticator.cc b/src/v/security/scram_authenticator.cc index 2d96e5e0c6ac..87b711908d3e 100644 --- a/src/v/security/scram_authenticator.cc +++ b/src/v/security/scram_authenticator.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/scram_authenticator.h b/src/v/security/scram_authenticator.h index fd82870b6fdc..3e82b05888ca 100644 --- a/src/v/security/scram_authenticator.h +++ b/src/v/security/scram_authenticator.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/tests/authorizer_test.cc b/src/v/security/tests/authorizer_test.cc index 33ac142c7e72..c9cd2cb886ad 100644 --- a/src/v/security/tests/authorizer_test.cc +++ b/src/v/security/tests/authorizer_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/security/tests/credential_store_test.cc b/src/v/security/tests/credential_store_test.cc index e9361e72364d..73ef09407edb 100644 --- a/src/v/security/tests/credential_store_test.cc +++ b/src/v/security/tests/credential_store_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/security/tests/scram_algorithm_test.cc b/src/v/security/tests/scram_algorithm_test.cc index e7e99dbb391e..057698472cbb 100644 --- a/src/v/security/tests/scram_algorithm_test.cc +++ b/src/v/security/tests/scram_algorithm_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/test/bench.cc b/src/v/serde/test/bench.cc index cdfae0cd5bfa..4d1579b5e126 100644 --- a/src/v/serde/test/bench.cc +++ b/src/v/serde/test/bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/ssx/future-util.h b/src/v/ssx/future-util.h index 96d115387194..8ff93caa27f3 100644 --- a/src/v/ssx/future-util.h +++ b/src/v/ssx/future-util.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/ssx/sformat.h b/src/v/ssx/sformat.h index 3924ce101d66..25c75e9d62b5 100644 --- a/src/v/ssx/sformat.h +++ b/src/v/ssx/sformat.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/ssx/tests/async_transforms.cc b/src/v/ssx/tests/async_transforms.cc index 233b8d255ec5..d78c38ef6bcd 100644 --- a/src/v/ssx/tests/async_transforms.cc +++ b/src/v/ssx/tests/async_transforms.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/ssx/tests/sformat.cc b/src/v/ssx/tests/sformat.cc index 70befc473ec5..cd2de7afc6ed 100644 --- a/src/v/ssx/tests/sformat.cc +++ b/src/v/ssx/tests/sformat.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/ssx/tests/sformat_bench.cc b/src/v/ssx/tests/sformat_bench.cc index 5a81624f026f..f10d06043745 100644 --- a/src/v/ssx/tests/sformat_bench.cc +++ b/src/v/ssx/tests/sformat_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/static_deleter_fn.h b/src/v/static_deleter_fn.h index f99944eeaf8f..155a9ef9731b 100644 --- a/src/v/static_deleter_fn.h +++ b/src/v/static_deleter_fn.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/api.h b/src/v/storage/api.h index cd30a450696c..69718e62e34b 100644 --- a/src/v/storage/api.h +++ b/src/v/storage/api.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/backlog_controller.cc b/src/v/storage/backlog_controller.cc index c24c2c21b119..66f0bb426077 100644 --- a/src/v/storage/backlog_controller.cc +++ b/src/v/storage/backlog_controller.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/backlog_controller.h b/src/v/storage/backlog_controller.h index 269bf2e36274..72d40357fc7a 100644 --- a/src/v/storage/backlog_controller.h +++ b/src/v/storage/backlog_controller.h @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/batch_cache.cc b/src/v/storage/batch_cache.cc index 7131155377ed..f8ff66b84977 100644 --- a/src/v/storage/batch_cache.cc +++ b/src/v/storage/batch_cache.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/batch_cache.h b/src/v/storage/batch_cache.h index ec3dd59f5c7e..833c68595055 100644 --- a/src/v/storage/batch_cache.h +++ b/src/v/storage/batch_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_index.h b/src/v/storage/compacted_index.h index 2f9aa66d3332..5068c2007c1a 100644 --- a/src/v/storage/compacted_index.h +++ b/src/v/storage/compacted_index.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_index_chunk_reader.cc b/src/v/storage/compacted_index_chunk_reader.cc index bd33e2b4916e..0ca818ebe99a 100644 --- a/src/v/storage/compacted_index_chunk_reader.cc +++ b/src/v/storage/compacted_index_chunk_reader.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_index_chunk_reader.h b/src/v/storage/compacted_index_chunk_reader.h index abb32fe28b9d..b2d56707f3be 100644 --- a/src/v/storage/compacted_index_chunk_reader.h +++ b/src/v/storage/compacted_index_chunk_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_index_reader.h b/src/v/storage/compacted_index_reader.h index bc905dadc764..1016081bbd7a 100644 --- a/src/v/storage/compacted_index_reader.h +++ b/src/v/storage/compacted_index_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_index_writer.h b/src/v/storage/compacted_index_writer.h index 3f66bbac8f11..ae51189c7648 100644 --- a/src/v/storage/compacted_index_writer.h +++ b/src/v/storage/compacted_index_writer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compacted_offset_list.h b/src/v/storage/compacted_offset_list.h index a7f3cb88f066..a9a99ed2b147 100644 --- a/src/v/storage/compacted_offset_list.h +++ b/src/v/storage/compacted_offset_list.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compaction_controller.cc b/src/v/storage/compaction_controller.cc index 15c6e784cd1c..0ce1a0f68147 100644 --- a/src/v/storage/compaction_controller.cc +++ b/src/v/storage/compaction_controller.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compaction_controller.h b/src/v/storage/compaction_controller.h index 704dea82955c..713e5e401923 100644 --- a/src/v/storage/compaction_controller.h +++ b/src/v/storage/compaction_controller.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/compaction_reducers.cc b/src/v/storage/compaction_reducers.cc index dd3bdb1caae9..7e7d8fa04f14 100644 --- a/src/v/storage/compaction_reducers.cc +++ b/src/v/storage/compaction_reducers.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/compaction_reducers.h b/src/v/storage/compaction_reducers.h index 015a4709c939..864b7181e0e3 100644 --- a/src/v/storage/compaction_reducers.h +++ b/src/v/storage/compaction_reducers.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/directories.h b/src/v/storage/directories.h index 4bbd98b46237..bf2f4bd83f05 100644 --- a/src/v/storage/directories.h +++ b/src/v/storage/directories.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/disk_log_appender.cc b/src/v/storage/disk_log_appender.cc index 198084c5e409..c013e30b945a 100644 --- a/src/v/storage/disk_log_appender.cc +++ b/src/v/storage/disk_log_appender.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/disk_log_appender.h b/src/v/storage/disk_log_appender.h index f0c369bfde8a..dfbf948897bc 100644 --- a/src/v/storage/disk_log_appender.h +++ b/src/v/storage/disk_log_appender.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/disk_log_impl.cc b/src/v/storage/disk_log_impl.cc index 67da4395b907..001a082dd3c2 100644 --- a/src/v/storage/disk_log_impl.cc +++ b/src/v/storage/disk_log_impl.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/disk_log_impl.h b/src/v/storage/disk_log_impl.h index 0a80db57d3d1..8381458bf5e0 100644 --- a/src/v/storage/disk_log_impl.h +++ b/src/v/storage/disk_log_impl.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/exceptions.h b/src/v/storage/exceptions.h index 0a4ca30e84dc..188ba7d5bb4a 100644 --- a/src/v/storage/exceptions.h +++ b/src/v/storage/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/failure_probes.h b/src/v/storage/failure_probes.h index 5fa55bd4dbd9..30af798c4509 100644 --- a/src/v/storage/failure_probes.h +++ b/src/v/storage/failure_probes.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/fs_utils.h b/src/v/storage/fs_utils.h index cdab4ea2d3d5..fb5a75fa65c7 100644 --- a/src/v/storage/fs_utils.h +++ b/src/v/storage/fs_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/fwd.h b/src/v/storage/fwd.h index a8c366a172f0..fc78e7fc90ee 100644 --- a/src/v/storage/fwd.h +++ b/src/v/storage/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/index_state.cc b/src/v/storage/index_state.cc index 95d656dd214d..9c36ddb8c07b 100644 --- a/src/v/storage/index_state.cc +++ b/src/v/storage/index_state.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/index_state.h b/src/v/storage/index_state.h index a79846749199..a08eb9b60f5f 100644 --- a/src/v/storage/index_state.h +++ b/src/v/storage/index_state.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/kvstore.cc b/src/v/storage/kvstore.cc index cfa36bbb3154..29dce19c0283 100644 --- a/src/v/storage/kvstore.cc +++ b/src/v/storage/kvstore.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/kvstore.h b/src/v/storage/kvstore.h index 3fd21cb30b87..c887977b2726 100644 --- a/src/v/storage/kvstore.h +++ b/src/v/storage/kvstore.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/lock_manager.cc b/src/v/storage/lock_manager.cc index a256c86a4be0..e0a502777573 100644 --- a/src/v/storage/lock_manager.cc +++ b/src/v/storage/lock_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/lock_manager.h b/src/v/storage/lock_manager.h index 44a84ee9a6d3..f14550b70b7f 100644 --- a/src/v/storage/lock_manager.h +++ b/src/v/storage/lock_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log.h b/src/v/storage/log.h index 8e5eb07b586e..a00e0490d3e5 100644 --- a/src/v/storage/log.h +++ b/src/v/storage/log.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log_appender.h b/src/v/storage/log_appender.h index 5e605f7bd8b9..6d154cfad0dc 100644 --- a/src/v/storage/log_appender.h +++ b/src/v/storage/log_appender.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log_housekeeping_meta.h b/src/v/storage/log_housekeeping_meta.h index 06c37b04b46d..b2b36f85fb07 100644 --- a/src/v/storage/log_housekeeping_meta.h +++ b/src/v/storage/log_housekeeping_meta.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log_manager.cc b/src/v/storage/log_manager.cc index 87868113e368..133fc6a0f27e 100644 --- a/src/v/storage/log_manager.cc +++ b/src/v/storage/log_manager.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/log_manager.h b/src/v/storage/log_manager.h index 63176f0edbda..dc269fb5e23c 100644 --- a/src/v/storage/log_manager.h +++ b/src/v/storage/log_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log_reader.cc b/src/v/storage/log_reader.cc index 1d8d604b5461..b027b7a0a263 100644 --- a/src/v/storage/log_reader.cc +++ b/src/v/storage/log_reader.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/log_reader.h b/src/v/storage/log_reader.h index 99f5916d67e2..6abae4062487 100644 --- a/src/v/storage/log_reader.h +++ b/src/v/storage/log_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/log_replayer.cc b/src/v/storage/log_replayer.cc index aca584a34c10..4a8548f9a743 100644 --- a/src/v/storage/log_replayer.cc +++ b/src/v/storage/log_replayer.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/log_replayer.h b/src/v/storage/log_replayer.h index 556527687465..df8a3564e17e 100644 --- a/src/v/storage/log_replayer.h +++ b/src/v/storage/log_replayer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/logger.cc b/src/v/storage/logger.cc index 4df438afacb0..3de5c2873d3a 100644 --- a/src/v/storage/logger.cc +++ b/src/v/storage/logger.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/logger.h b/src/v/storage/logger.h index 2f2a023d48d7..cc0b2f91d7c5 100644 --- a/src/v/storage/logger.h +++ b/src/v/storage/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/mem_log_impl.cc b/src/v/storage/mem_log_impl.cc index f92ec0abae92..032271d03d88 100644 --- a/src/v/storage/mem_log_impl.cc +++ b/src/v/storage/mem_log_impl.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/ntp_config.h b/src/v/storage/ntp_config.h index b860ea5543d5..0d586caaf228 100644 --- a/src/v/storage/ntp_config.h +++ b/src/v/storage/ntp_config.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/offset_assignment.h b/src/v/storage/offset_assignment.h index 65fca4c43b72..2a5c0d210171 100644 --- a/src/v/storage/offset_assignment.h +++ b/src/v/storage/offset_assignment.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/offset_to_filepos_consumer.h b/src/v/storage/offset_to_filepos_consumer.h index 96ef934b0903..717222cc1177 100644 --- a/src/v/storage/offset_to_filepos_consumer.h +++ b/src/v/storage/offset_to_filepos_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/opfuzz/opfuzz.cc b/src/v/storage/opfuzz/opfuzz.cc index e88b9ed026b4..e1d652bac2b3 100644 --- a/src/v/storage/opfuzz/opfuzz.cc +++ b/src/v/storage/opfuzz/opfuzz.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/opfuzz/opfuzz.h b/src/v/storage/opfuzz/opfuzz.h index 4c57bae40b64..644266745bdb 100644 --- a/src/v/storage/opfuzz/opfuzz.h +++ b/src/v/storage/opfuzz/opfuzz.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/opfuzz/opfuzz_test.cc b/src/v/storage/opfuzz/opfuzz_test.cc index 515d94d3d0d0..51ffe033d9d4 100644 --- a/src/v/storage/opfuzz/opfuzz_test.cc +++ b/src/v/storage/opfuzz/opfuzz_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/parser.cc b/src/v/storage/parser.cc index b9749546c774..cfdf8a1dcca9 100644 --- a/src/v/storage/parser.cc +++ b/src/v/storage/parser.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/parser.h b/src/v/storage/parser.h index 6872b2972382..dc85213aea62 100644 --- a/src/v/storage/parser.h +++ b/src/v/storage/parser.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/parser_errc.h b/src/v/storage/parser_errc.h index 6529d1f579a4..08e0063da01b 100644 --- a/src/v/storage/parser_errc.h +++ b/src/v/storage/parser_errc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/parser_utils.cc b/src/v/storage/parser_utils.cc index 8a6664890d59..c51b1333b99a 100644 --- a/src/v/storage/parser_utils.cc +++ b/src/v/storage/parser_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/parser_utils.h b/src/v/storage/parser_utils.h index 4462c26377f7..46059bd6a81c 100644 --- a/src/v/storage/parser_utils.h +++ b/src/v/storage/parser_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/probe.cc b/src/v/storage/probe.cc index 21734e1baca0..bc8c2c0ea352 100644 --- a/src/v/storage/probe.cc +++ b/src/v/storage/probe.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/probe.h b/src/v/storage/probe.h index 6cfdcd467272..d92695861c8a 100644 --- a/src/v/storage/probe.h +++ b/src/v/storage/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/readers_cache.cc b/src/v/storage/readers_cache.cc index cf767a6f2add..0c68f2f8708a 100644 --- a/src/v/storage/readers_cache.cc +++ b/src/v/storage/readers_cache.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/readers_cache.h b/src/v/storage/readers_cache.h index 880e655e0c7c..b5a867f52593 100644 --- a/src/v/storage/readers_cache.h +++ b/src/v/storage/readers_cache.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/record_batch_builder.cc b/src/v/storage/record_batch_builder.cc index 74d8b3fbb4bc..fe842298f7f2 100644 --- a/src/v/storage/record_batch_builder.cc +++ b/src/v/storage/record_batch_builder.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/record_batch_builder.h b/src/v/storage/record_batch_builder.h index bf44fdcf3429..e8c1ce338a30 100644 --- a/src/v/storage/record_batch_builder.h +++ b/src/v/storage/record_batch_builder.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment.cc b/src/v/storage/segment.cc index 59174474318a..e7487a30a762 100644 --- a/src/v/storage/segment.cc +++ b/src/v/storage/segment.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment.h b/src/v/storage/segment.h index 92544aa99b00..febc152c3b2f 100644 --- a/src/v/storage/segment.h +++ b/src/v/storage/segment.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_appender.cc b/src/v/storage/segment_appender.cc index 9f7cbf39b123..ffd35d570832 100644 --- a/src/v/storage/segment_appender.cc +++ b/src/v/storage/segment_appender.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_appender.h b/src/v/storage/segment_appender.h index fa16f766c568..f31cb2ce210c 100644 --- a/src/v/storage/segment_appender.h +++ b/src/v/storage/segment_appender.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_appender_chunk.h b/src/v/storage/segment_appender_chunk.h index 7c22a10307d2..b52bdb145cab 100644 --- a/src/v/storage/segment_appender_chunk.h +++ b/src/v/storage/segment_appender_chunk.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_appender_utils.cc b/src/v/storage/segment_appender_utils.cc index 322c933d3753..f6dc14d03bc3 100644 --- a/src/v/storage/segment_appender_utils.cc +++ b/src/v/storage/segment_appender_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_appender_utils.h b/src/v/storage/segment_appender_utils.h index d00bbe477ca4..36210641dd95 100644 --- a/src/v/storage/segment_appender_utils.h +++ b/src/v/storage/segment_appender_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_index.cc b/src/v/storage/segment_index.cc index b1b65df8c6fc..8d0b655c2d79 100644 --- a/src/v/storage/segment_index.cc +++ b/src/v/storage/segment_index.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_index.h b/src/v/storage/segment_index.h index 17aa1fc750b3..6317fe364191 100644 --- a/src/v/storage/segment_index.h +++ b/src/v/storage/segment_index.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_reader.cc b/src/v/storage/segment_reader.cc index 1224eb28469a..ecbc4e2b66c2 100644 --- a/src/v/storage/segment_reader.cc +++ b/src/v/storage/segment_reader.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_reader.h b/src/v/storage/segment_reader.h index 8d38f6c520a5..3e3c905716d4 100644 --- a/src/v/storage/segment_reader.h +++ b/src/v/storage/segment_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_set.cc b/src/v/storage/segment_set.cc index 4010a204987d..72b7c627c261 100644 --- a/src/v/storage/segment_set.cc +++ b/src/v/storage/segment_set.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_set.h b/src/v/storage/segment_set.h index 364eb70485ff..6a2a18143b18 100644 --- a/src/v/storage/segment_set.h +++ b/src/v/storage/segment_set.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/segment_utils.cc b/src/v/storage/segment_utils.cc index 477e5265537a..a657b739b604 100644 --- a/src/v/storage/segment_utils.cc +++ b/src/v/storage/segment_utils.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/segment_utils.h b/src/v/storage/segment_utils.h index bc5541fceeae..fbdbfa97b748 100644 --- a/src/v/storage/segment_utils.h +++ b/src/v/storage/segment_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/shard_assignment.h b/src/v/storage/shard_assignment.h index dd62212aff86..e4296a2a4da9 100644 --- a/src/v/storage/shard_assignment.h +++ b/src/v/storage/shard_assignment.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/snapshot.cc b/src/v/storage/snapshot.cc index 4ef9afd62df7..fe4e9d3514cc 100644 --- a/src/v/storage/snapshot.cc +++ b/src/v/storage/snapshot.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/snapshot.h b/src/v/storage/snapshot.h index f131215ac67d..bd1d91cf6176 100644 --- a/src/v/storage/snapshot.h +++ b/src/v/storage/snapshot.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/spill_key_index.cc b/src/v/storage/spill_key_index.cc index df735bc0b3f0..df06dcf12e1e 100644 --- a/src/v/storage/spill_key_index.cc +++ b/src/v/storage/spill_key_index.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/spill_key_index.h b/src/v/storage/spill_key_index.h index 0b4a95b9cc93..22deace234a5 100644 --- a/src/v/storage/spill_key_index.h +++ b/src/v/storage/spill_key_index.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/tests/appender_chunk_manipulations.cc b/src/v/storage/tests/appender_chunk_manipulations.cc index 4d886fa49d9b..fae2e402329a 100644 --- a/src/v/storage/tests/appender_chunk_manipulations.cc +++ b/src/v/storage/tests/appender_chunk_manipulations.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/backlog_controller_test.cc b/src/v/storage/tests/backlog_controller_test.cc index ac9bf5cc3d74..5a0b359e0c45 100644 --- a/src/v/storage/tests/backlog_controller_test.cc +++ b/src/v/storage/tests/backlog_controller_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/batch_cache_reclaim_test.cc b/src/v/storage/tests/batch_cache_reclaim_test.cc index c67d51b54635..764b680de4ec 100644 --- a/src/v/storage/tests/batch_cache_reclaim_test.cc +++ b/src/v/storage/tests/batch_cache_reclaim_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/batch_cache_test.cc b/src/v/storage/tests/batch_cache_test.cc index 5c4e5a01cc7d..6273ac1e0c5f 100644 --- a/src/v/storage/tests/batch_cache_test.cc +++ b/src/v/storage/tests/batch_cache_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/compaction_idx_bench.cc b/src/v/storage/tests/compaction_idx_bench.cc index 7a6f54ab7670..6afeae1cf656 100644 --- a/src/v/storage/tests/compaction_idx_bench.cc +++ b/src/v/storage/tests/compaction_idx_bench.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/compaction_index_format_tests.cc b/src/v/storage/tests/compaction_index_format_tests.cc index 2d463a69f42b..3c2e5cbafb0f 100644 --- a/src/v/storage/tests/compaction_index_format_tests.cc +++ b/src/v/storage/tests/compaction_index_format_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/disk_log_builder_fixture.h b/src/v/storage/tests/disk_log_builder_fixture.h index 2e6c4e99f24a..c2f7e47bea36 100644 --- a/src/v/storage/tests/disk_log_builder_fixture.h +++ b/src/v/storage/tests/disk_log_builder_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/tests/disk_log_builder_test.cc b/src/v/storage/tests/disk_log_builder_test.cc index ae32cb05589b..1e72e2c1570c 100644 --- a/src/v/storage/tests/disk_log_builder_test.cc +++ b/src/v/storage/tests/disk_log_builder_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/half_page_concurrent_dispatch.cc b/src/v/storage/tests/half_page_concurrent_dispatch.cc index 937ae99ad574..6283e25cc210 100644 --- a/src/v/storage/tests/half_page_concurrent_dispatch.cc +++ b/src/v/storage/tests/half_page_concurrent_dispatch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/kvstore_test.cc b/src/v/storage/tests/kvstore_test.cc index 6c9800171f29..309f05648d82 100644 --- a/src/v/storage/tests/kvstore_test.cc +++ b/src/v/storage/tests/kvstore_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_manager_test.cc b/src/v/storage/tests/log_manager_test.cc index 874b30058b83..632205cbabe9 100644 --- a/src/v/storage/tests/log_manager_test.cc +++ b/src/v/storage/tests/log_manager_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_replayer_test.cc b/src/v/storage/tests/log_replayer_test.cc index 9c4605579daa..b521b5c6ac92 100644 --- a/src/v/storage/tests/log_replayer_test.cc +++ b/src/v/storage/tests/log_replayer_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_retention_tests.cc b/src/v/storage/tests/log_retention_tests.cc index 392266009c07..b6e9079338c7 100644 --- a/src/v/storage/tests/log_retention_tests.cc +++ b/src/v/storage/tests/log_retention_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_segment_appender_test.cc b/src/v/storage/tests/log_segment_appender_test.cc index 5aae32a45a65..5997394015af 100644 --- a/src/v/storage/tests/log_segment_appender_test.cc +++ b/src/v/storage/tests/log_segment_appender_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_segment_reader_test.cc b/src/v/storage/tests/log_segment_reader_test.cc index e7820117850e..85b445aa1e3a 100644 --- a/src/v/storage/tests/log_segment_reader_test.cc +++ b/src/v/storage/tests/log_segment_reader_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/log_truncate_test.cc b/src/v/storage/tests/log_truncate_test.cc index 8430a343a037..1070154cfe31 100644 --- a/src/v/storage/tests/log_truncate_test.cc +++ b/src/v/storage/tests/log_truncate_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/offset_assignment_test.cc b/src/v/storage/tests/offset_assignment_test.cc index 89260d29a02d..ac9f0b2964de 100644 --- a/src/v/storage/tests/offset_assignment_test.cc +++ b/src/v/storage/tests/offset_assignment_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/offset_index_utils_tests.cc b/src/v/storage/tests/offset_index_utils_tests.cc index 436c88c10dd6..aa7b27550f1d 100644 --- a/src/v/storage/tests/offset_index_utils_tests.cc +++ b/src/v/storage/tests/offset_index_utils_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/produce_consume_test.cc b/src/v/storage/tests/produce_consume_test.cc index 5f64ca49185b..8f2799796bbd 100644 --- a/src/v/storage/tests/produce_consume_test.cc +++ b/src/v/storage/tests/produce_consume_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/record_batch_builder_test.cc b/src/v/storage/tests/record_batch_builder_test.cc index fd099817b24c..7797094466d9 100644 --- a/src/v/storage/tests/record_batch_builder_test.cc +++ b/src/v/storage/tests/record_batch_builder_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/tests/segment_size_jitter_test.cc b/src/v/storage/tests/segment_size_jitter_test.cc index 21f8d604f64e..87b6c4dfa8bf 100644 --- a/src/v/storage/tests/segment_size_jitter_test.cc +++ b/src/v/storage/tests/segment_size_jitter_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/snapshot_test.cc b/src/v/storage/tests/snapshot_test.cc index 9eb120fdf7bd..d371c20f6efc 100644 --- a/src/v/storage/tests/snapshot_test.cc +++ b/src/v/storage/tests/snapshot_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/storage_e2e_test.cc b/src/v/storage/tests/storage_e2e_test.cc index 3244c5f3cc48..0719627c9c60 100644 --- a/src/v/storage/tests/storage_e2e_test.cc +++ b/src/v/storage/tests/storage_e2e_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/storage_test_fixture.h b/src/v/storage/tests/storage_test_fixture.h index 819371afd66f..5f7f92e0e124 100644 --- a/src/v/storage/tests/storage_test_fixture.h +++ b/src/v/storage/tests/storage_test_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/tests/timequery_test.cc b/src/v/storage/tests/timequery_test.cc index 897d9d87536a..2ae121e7a7d4 100644 --- a/src/v/storage/tests/timequery_test.cc +++ b/src/v/storage/tests/timequery_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/utils/disk_log_builder.cc b/src/v/storage/tests/utils/disk_log_builder.cc index f4a8afa8edd9..43c17a963c0c 100644 --- a/src/v/storage/tests/utils/disk_log_builder.cc +++ b/src/v/storage/tests/utils/disk_log_builder.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/utils/disk_log_builder.h b/src/v/storage/tests/utils/disk_log_builder.h index 2af5aed77c6c..341311b1b8f7 100644 --- a/src/v/storage/tests/utils/disk_log_builder.h +++ b/src/v/storage/tests/utils/disk_log_builder.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/tests/utils/random_batch.cc b/src/v/storage/tests/utils/random_batch.cc index 8b557eaf6fee..2d07ddc0b8ca 100644 --- a/src/v/storage/tests/utils/random_batch.cc +++ b/src/v/storage/tests/utils/random_batch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/tests/utils/random_batch.h b/src/v/storage/tests/utils/random_batch.h index f5fe5194941e..9ab4ad3ab32d 100644 --- a/src/v/storage/tests/utils/random_batch.h +++ b/src/v/storage/tests/utils/random_batch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/types.cc b/src/v/storage/types.cc index 935118b33e9f..4bd17dcab0aa 100644 --- a/src/v/storage/types.cc +++ b/src/v/storage/types.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/types.h b/src/v/storage/types.h index 2ce007672a79..714c64a3ffcc 100644 --- a/src/v/storage/types.h +++ b/src/v/storage/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/utils/transforming_reader.h b/src/v/storage/utils/transforming_reader.h index 5d1dbff8cb3f..c50d32f20556 100644 --- a/src/v/storage/utils/transforming_reader.h +++ b/src/v/storage/utils/transforming_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/version.h b/src/v/storage/version.h index 6736b888bcbc..f776719ed29b 100644 --- a/src/v/storage/version.h +++ b/src/v/storage/version.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/syschecks/pidfile.cc b/src/v/syschecks/pidfile.cc index dde26f4fc346..af639f6239f3 100644 --- a/src/v/syschecks/pidfile.cc +++ b/src/v/syschecks/pidfile.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/syschecks/syschecks.cc b/src/v/syschecks/syschecks.cc index b857703d1159..86f65ec6d726 100644 --- a/src/v/syschecks/syschecks.cc +++ b/src/v/syschecks/syschecks.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/syschecks/syschecks.h b/src/v/syschecks/syschecks.h index 47336f558616..33997c32df10 100644 --- a/src/v/syschecks/syschecks.h +++ b/src/v/syschecks/syschecks.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/async.h b/src/v/test_utils/async.h index cac21e458f00..678ed2595123 100644 --- a/src/v/test_utils/async.h +++ b/src/v/test_utils/async.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/fixture.h b/src/v/test_utils/fixture.h index 4e39df069316..58c077bac8d7 100644 --- a/src/v/test_utils/fixture.h +++ b/src/v/test_utils/fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/logs.h b/src/v/test_utils/logs.h index b53bcc13092f..4a3bae86310e 100644 --- a/src/v/test_utils/logs.h +++ b/src/v/test_utils/logs.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/non_root_port.h b/src/v/test_utils/non_root_port.h index 014deaabce99..057e805bc334 100644 --- a/src/v/test_utils/non_root_port.h +++ b/src/v/test_utils/non_root_port.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/randoms.h b/src/v/test_utils/randoms.h index f94234afd3d5..8641d8514259 100644 --- a/src/v/test_utils/randoms.h +++ b/src/v/test_utils/randoms.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/rpc.h b/src/v/test_utils/rpc.h index c1d358098f78..1bf7672ad612 100644 --- a/src/v/test_utils/rpc.h +++ b/src/v/test_utils/rpc.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/test_utils/seastar_testing_main.cc b/src/v/test_utils/seastar_testing_main.cc index b3fd7a869a9f..e0d332caf6f2 100644 --- a/src/v/test_utils/seastar_testing_main.cc +++ b/src/v/test_utils/seastar_testing_main.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/test_utils/tmp_dir.h b/src/v/test_utils/tmp_dir.h index f73f2151ba9b..8e53cf5c299e 100644 --- a/src/v/test_utils/tmp_dir.h +++ b/src/v/test_utils/tmp_dir.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/tristate.h b/src/v/tristate.h index b90c0d1b196c..a0b2987213bc 100644 --- a/src/v/tristate.h +++ b/src/v/tristate.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/units.h b/src/v/units.h index dcc22a154308..021ec6938893 100644 --- a/src/v/units.h +++ b/src/v/units.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/absl_sstring_hash.h b/src/v/utils/absl_sstring_hash.h index c6c160f03063..7417368dd260 100644 --- a/src/v/utils/absl_sstring_hash.h +++ b/src/v/utils/absl_sstring_hash.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/available_promise.h b/src/v/utils/available_promise.h index 766c8f755aea..f994b07ea141 100644 --- a/src/v/utils/available_promise.h +++ b/src/v/utils/available_promise.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/base64.cc b/src/v/utils/base64.cc index bb922e383d78..ba8c6a30d747 100644 --- a/src/v/utils/base64.cc +++ b/src/v/utils/base64.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/base64.h b/src/v/utils/base64.h index 3370fb3852ab..fde69875dc63 100644 --- a/src/v/utils/base64.h +++ b/src/v/utils/base64.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/concepts-enabled.h b/src/v/utils/concepts-enabled.h index a7a99891afa4..2932576bfa69 100644 --- a/src/v/utils/concepts-enabled.h +++ b/src/v/utils/concepts-enabled.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/copy_range.h b/src/v/utils/copy_range.h index afe5ee3c3b03..5f6e21220b5c 100644 --- a/src/v/utils/copy_range.h +++ b/src/v/utils/copy_range.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/directory_walker.h b/src/v/utils/directory_walker.h index 1e03c22ffca3..73f723c2009d 100644 --- a/src/v/utils/directory_walker.h +++ b/src/v/utils/directory_walker.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/expiring_promise.h b/src/v/utils/expiring_promise.h index bcbce2c51fee..693639a07b08 100644 --- a/src/v/utils/expiring_promise.h +++ b/src/v/utils/expiring_promise.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/file_io.cc b/src/v/utils/file_io.cc index 59e79d7b1fb0..40c1a3437b15 100644 --- a/src/v/utils/file_io.cc +++ b/src/v/utils/file_io.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/file_io.h b/src/v/utils/file_io.h index c1240c4fd515..0bffb7ef7dfe 100644 --- a/src/v/utils/file_io.h +++ b/src/v/utils/file_io.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/file_sanitizer.h b/src/v/utils/file_sanitizer.h index 1549ef5e9bb7..ebabf6cd16ce 100644 --- a/src/v/utils/file_sanitizer.h +++ b/src/v/utils/file_sanitizer.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/fragmented_vector.h b/src/v/utils/fragmented_vector.h index b26a64425c8b..bb838ba71046 100644 --- a/src/v/utils/fragmented_vector.h +++ b/src/v/utils/fragmented_vector.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/functional.h b/src/v/utils/functional.h index 017cb3805143..23d22319fe77 100644 --- a/src/v/utils/functional.h +++ b/src/v/utils/functional.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/hdr_hist.cc b/src/v/utils/hdr_hist.cc index c696b6bc0295..584b7601241a 100644 --- a/src/v/utils/hdr_hist.cc +++ b/src/v/utils/hdr_hist.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/hdr_hist.h b/src/v/utils/hdr_hist.h index 17cff958a688..ed903fe86b14 100644 --- a/src/v/utils/hdr_hist.h +++ b/src/v/utils/hdr_hist.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/human.cc b/src/v/utils/human.cc index de6dd57a0303..a9b0b36437a0 100644 --- a/src/v/utils/human.cc +++ b/src/v/utils/human.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/human.h b/src/v/utils/human.h index 57cb69bb6e99..42da19484061 100644 --- a/src/v/utils/human.h +++ b/src/v/utils/human.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/intrusive_list_helpers.h b/src/v/utils/intrusive_list_helpers.h index 665d763a3dd4..64b9c9683176 100644 --- a/src/v/utils/intrusive_list_helpers.h +++ b/src/v/utils/intrusive_list_helpers.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/memory_data_source.h b/src/v/utils/memory_data_source.h index 49a0cd9a57ea..7e9e1d063c7e 100644 --- a/src/v/utils/memory_data_source.h +++ b/src/v/utils/memory_data_source.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/mutex.h b/src/v/utils/mutex.h index 815e6bdd465f..267d646cffd7 100644 --- a/src/v/utils/mutex.h +++ b/src/v/utils/mutex.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/named_type.h b/src/v/utils/named_type.h index 5cdc282f6775..e99c56f4d2f2 100644 --- a/src/v/utils/named_type.h +++ b/src/v/utils/named_type.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/remote.h b/src/v/utils/remote.h index 61cb8871415b..3b61816c163f 100644 --- a/src/v/utils/remote.h +++ b/src/v/utils/remote.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/retry.h b/src/v/utils/retry.h index 3b63cf767ed2..2888de375e96 100644 --- a/src/v/utils/retry.h +++ b/src/v/utils/retry.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/retry_chain_node.cc b/src/v/utils/retry_chain_node.cc index 0d53b832b8ba..a684ec93b4a5 100644 --- a/src/v/utils/retry_chain_node.cc +++ b/src/v/utils/retry_chain_node.cc @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/retry_chain_node.h b/src/v/utils/retry_chain_node.h index 79be5bcece6e..9b445bbba509 100644 --- a/src/v/utils/retry_chain_node.h +++ b/src/v/utils/retry_chain_node.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/string_switch.h b/src/v/utils/string_switch.h index 3c25aba056fa..f71d17ec2080 100644 --- a/src/v/utils/string_switch.h +++ b/src/v/utils/string_switch.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/tests/base64_test.cc b/src/v/utils/tests/base64_test.cc index 124d0239406a..65015f68e1be 100644 --- a/src/v/utils/tests/base64_test.cc +++ b/src/v/utils/tests/base64_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/constexpr_string_switch.cc b/src/v/utils/tests/constexpr_string_switch.cc index 1ffb9dadb267..72083fd0cbbc 100644 --- a/src/v/utils/tests/constexpr_string_switch.cc +++ b/src/v/utils/tests/constexpr_string_switch.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/directory_walker_test.cc b/src/v/utils/tests/directory_walker_test.cc index 603ed68e34d6..58aadff26ca0 100644 --- a/src/v/utils/tests/directory_walker_test.cc +++ b/src/v/utils/tests/directory_walker_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/named_type_tests.cc b/src/v/utils/tests/named_type_tests.cc index 0f0e26417109..a5208711565e 100644 --- a/src/v/utils/tests/named_type_tests.cc +++ b/src/v/utils/tests/named_type_tests.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/outcome_utils_test.cc b/src/v/utils/tests/outcome_utils_test.cc index 924048b972b3..8458c73a7c8c 100644 --- a/src/v/utils/tests/outcome_utils_test.cc +++ b/src/v/utils/tests/outcome_utils_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/remote_test.cc b/src/v/utils/tests/remote_test.cc index 3aac096f5df2..f60a577e828e 100644 --- a/src/v/utils/tests/remote_test.cc +++ b/src/v/utils/tests/remote_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/retry_chain_node_test.cc b/src/v/utils/tests/retry_chain_node_test.cc index 3c8f5b66c35d..dd9a24128b11 100644 --- a/src/v/utils/tests/retry_chain_node_test.cc +++ b/src/v/utils/tests/retry_chain_node_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/retry_test.cc b/src/v/utils/tests/retry_test.cc index 79c8cd9d1ac2..8cf3588edc5f 100644 --- a/src/v/utils/tests/retry_test.cc +++ b/src/v/utils/tests/retry_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/string_switch_test.cc b/src/v/utils/tests/string_switch_test.cc index 09e8b94459aa..bcb51ee6ca6f 100644 --- a/src/v/utils/tests/string_switch_test.cc +++ b/src/v/utils/tests/string_switch_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/tristate_test.cc b/src/v/utils/tests/tristate_test.cc index 1ad00db3e8a2..6d6bd2231541 100644 --- a/src/v/utils/tests/tristate_test.cc +++ b/src/v/utils/tests/tristate_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/vint_test.cc b/src/v/utils/tests/vint_test.cc index 7fc3be1c7622..aa83bf7af499 100644 --- a/src/v/utils/tests/vint_test.cc +++ b/src/v/utils/tests/vint_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/waiter_queue_test.cc b/src/v/utils/tests/waiter_queue_test.cc index d29585085031..380818ebeb56 100644 --- a/src/v/utils/tests/waiter_queue_test.cc +++ b/src/v/utils/tests/waiter_queue_test.cc @@ -1,4 +1,4 @@ -// Copyright 2020 Vectorized, Inc. +// Copyright 2020 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/timed_mutex.h b/src/v/utils/timed_mutex.h index 3a163414a672..ae6ddd058f76 100644 --- a/src/v/utils/timed_mutex.h +++ b/src/v/utils/timed_mutex.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/to_string.h b/src/v/utils/to_string.h index 93608768ba07..e83af3c7a510 100644 --- a/src/v/utils/to_string.h +++ b/src/v/utils/to_string.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/utf8.h b/src/v/utils/utf8.h index 0112eb97f278..86834b30d67f 100644 --- a/src/v/utils/utf8.h +++ b/src/v/utils/utf8.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/vint.h b/src/v/utils/vint.h index ed8d37d3b5af..32fa4477a499 100644 --- a/src/v/utils/vint.h +++ b/src/v/utils/vint.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/vassert.h b/src/v/vassert.h index 6db25bf0b1f0..4e2d51949b3d 100644 --- a/src/v/vassert.h +++ b/src/v/vassert.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/vlog.h b/src/v/vlog.h index ef46160e08ea..6f99f34f82ce 100644 --- a/src/v/vlog.h +++ b/src/v/vlog.h @@ -1,5 +1,5 @@ /* - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/tests/rptest/__init__.py b/tests/rptest/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/__init__.py +++ b/tests/rptest/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/__init__.py b/tests/rptest/clients/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/clients/__init__.py +++ b/tests/rptest/clients/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/compacted_verifier.py b/tests/rptest/clients/compacted_verifier.py index dea8a8bccab0..8c719e13859f 100644 --- a/tests/rptest/clients/compacted_verifier.py +++ b/tests/rptest/clients/compacted_verifier.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/kafka_cat.py b/tests/rptest/clients/kafka_cat.py index 6b00f6ec787c..9663d079aa86 100644 --- a/tests/rptest/clients/kafka_cat.py +++ b/tests/rptest/clients/kafka_cat.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/kafka_cli_tools.py b/tests/rptest/clients/kafka_cli_tools.py index a68f21e287be..48235f7572b6 100644 --- a/tests/rptest/clients/kafka_cli_tools.py +++ b/tests/rptest/clients/kafka_cli_tools.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/python_librdkafka.py b/tests/rptest/clients/python_librdkafka.py index 0ab64aae0efd..db924ec95b39 100644 --- a/tests/rptest/clients/python_librdkafka.py +++ b/tests/rptest/clients/python_librdkafka.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/rpk.py b/tests/rptest/clients/rpk.py index e67a1542ec67..63edb5838d92 100644 --- a/tests/rptest/clients/rpk.py +++ b/tests/rptest/clients/rpk.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/__init__.py b/tests/rptest/services/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/services/__init__.py +++ b/tests/rptest/services/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/__init__.py b/tests/rptest/services/compatibility/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/services/compatibility/__init__.py +++ b/tests/rptest/services/compatibility/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/failure_injector.py b/tests/rptest/services/failure_injector.py index 6cd10a308d4e..c5f694529919 100644 --- a/tests/rptest/services/failure_injector.py +++ b/tests/rptest/services/failure_injector.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/http_server.py b/tests/rptest/services/http_server.py index 06ddcc218bdd..5dda749276a9 100644 --- a/tests/rptest/services/http_server.py +++ b/tests/rptest/services/http_server.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/kaf_consumer.py b/tests/rptest/services/kaf_consumer.py index 7cf778244d89..cd3cdc466287 100644 --- a/tests/rptest/services/kaf_consumer.py +++ b/tests/rptest/services/kaf_consumer.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/kaf_producer.py b/tests/rptest/services/kaf_producer.py index 49009f8eb6d4..267efee86a8b 100644 --- a/tests/rptest/services/kaf_producer.py +++ b/tests/rptest/services/kaf_producer.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/redpanda.py b/tests/rptest/services/redpanda.py index 079e31403c07..92ef96343cd9 100644 --- a/tests/rptest/services/redpanda.py +++ b/tests/rptest/services/redpanda.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/rpk_consumer.py b/tests/rptest/services/rpk_consumer.py index d47226ca13ab..8056515170e1 100644 --- a/tests/rptest/services/rpk_consumer.py +++ b/tests/rptest/services/rpk_consumer.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/storage.py b/tests/rptest/services/storage.py index 2b98a79912d6..89412101a8c1 100644 --- a/tests/rptest/services/storage.py +++ b/tests/rptest/services/storage.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/templates/redpanda.yaml b/tests/rptest/services/templates/redpanda.yaml index a2a2c0189e7c..18ec6f1d3e13 100644 --- a/tests/rptest/services/templates/redpanda.yaml +++ b/tests/rptest/services/templates/redpanda.yaml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/test_suite_all.yml b/tests/rptest/test_suite_all.yml index 1b663b85629b..12f4021eea88 100644 --- a/tests/rptest/test_suite_all.yml +++ b/tests/rptest/test_suite_all.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/test_suite_pandaproxy.yml b/tests/rptest/test_suite_pandaproxy.yml index 5089c9ab3456..11ccb8be8633 100644 --- a/tests/rptest/test_suite_pandaproxy.yml +++ b/tests/rptest/test_suite_pandaproxy.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/test_suite_quick.yml b/tests/rptest/test_suite_quick.yml index 1ee99e2efbf2..301244d87264 100644 --- a/tests/rptest/test_suite_quick.yml +++ b/tests/rptest/test_suite_quick.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/test_suite_wasm.yml b/tests/rptest/test_suite_wasm.yml index a9f2334219dd..d99aef8ae22c 100644 --- a/tests/rptest/test_suite_wasm.yml +++ b/tests/rptest/test_suite_wasm.yml @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/__init__.py b/tests/rptest/tests/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/tests/__init__.py +++ b/tests/rptest/tests/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/admin_api_auth_test.py b/tests/rptest/tests/admin_api_auth_test.py index 0a72ac0a19e4..5f3bdd84575f 100644 --- a/tests/rptest/tests/admin_api_auth_test.py +++ b/tests/rptest/tests/admin_api_auth_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/alter_topic_configuration_test.py b/tests/rptest/tests/alter_topic_configuration_test.py index 887a1b52dc5f..f13a327b09dc 100644 --- a/tests/rptest/tests/alter_topic_configuration_test.py +++ b/tests/rptest/tests/alter_topic_configuration_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/availability_test.py b/tests/rptest/tests/availability_test.py index b2875aa18941..2d35114562e8 100644 --- a/tests/rptest/tests/availability_test.py +++ b/tests/rptest/tests/availability_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/cluster_config_test.py b/tests/rptest/tests/cluster_config_test.py index 4d88f8b2dfa4..a8679e57b5cb 100644 --- a/tests/rptest/tests/cluster_config_test.py +++ b/tests/rptest/tests/cluster_config_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/cluster_metadata_test.py b/tests/rptest/tests/cluster_metadata_test.py index 29fcf45a4f82..b8b4f0b25278 100644 --- a/tests/rptest/tests/cluster_metadata_test.py +++ b/tests/rptest/tests/cluster_metadata_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/cluster_view_test.py b/tests/rptest/tests/cluster_view_test.py index 3103d9e17fd2..754b407d5fae 100644 --- a/tests/rptest/tests/cluster_view_test.py +++ b/tests/rptest/tests/cluster_view_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compacted_term_rolled_recovery_test.py b/tests/rptest/tests/compacted_term_rolled_recovery_test.py index e36eceecb063..4b23151f0bef 100644 --- a/tests/rptest/tests/compacted_term_rolled_recovery_test.py +++ b/tests/rptest/tests/compacted_term_rolled_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compacted_topic_verifier_test.py b/tests/rptest/tests/compacted_topic_verifier_test.py index fd8b045e301d..f257dc2cf7bd 100644 --- a/tests/rptest/tests/compacted_topic_verifier_test.py +++ b/tests/rptest/tests/compacted_topic_verifier_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compaction_recovery_test.py b/tests/rptest/tests/compaction_recovery_test.py index 60b0900d5487..a5d920e812cd 100644 --- a/tests/rptest/tests/compaction_recovery_test.py +++ b/tests/rptest/tests/compaction_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compatibility/__init__.py b/tests/rptest/tests/compatibility/__init__.py index 267c048b28f6..906f99c7c5ae 100644 --- a/tests/rptest/tests/compatibility/__init__.py +++ b/tests/rptest/tests/compatibility/__init__.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compatibility/sarama_produce_test.py b/tests/rptest/tests/compatibility/sarama_produce_test.py index 543eb560f94b..5750defba845 100644 --- a/tests/rptest/tests/compatibility/sarama_produce_test.py +++ b/tests/rptest/tests/compatibility/sarama_produce_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/configuration_update_test.py b/tests/rptest/tests/configuration_update_test.py index a3112f66ab1f..0f4761fa1abb 100644 --- a/tests/rptest/tests/configuration_update_test.py +++ b/tests/rptest/tests/configuration_update_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/controller_recovery_test.py b/tests/rptest/tests/controller_recovery_test.py index 3b45bed2146e..00864a602622 100644 --- a/tests/rptest/tests/controller_recovery_test.py +++ b/tests/rptest/tests/controller_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/create_partitions_test.py b/tests/rptest/tests/create_partitions_test.py index 18b354d520b1..b907946b6f95 100644 --- a/tests/rptest/tests/create_partitions_test.py +++ b/tests/rptest/tests/create_partitions_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/custom_topic_assignment_test.py b/tests/rptest/tests/custom_topic_assignment_test.py index bdab08a0bbb1..4dd4cb864994 100644 --- a/tests/rptest/tests/custom_topic_assignment_test.py +++ b/tests/rptest/tests/custom_topic_assignment_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/describe_topics_test.py b/tests/rptest/tests/describe_topics_test.py index 4f7710b5b5a7..4ee7529c48c1 100644 --- a/tests/rptest/tests/describe_topics_test.py +++ b/tests/rptest/tests/describe_topics_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/e2e_finjector.py b/tests/rptest/tests/e2e_finjector.py index 6bf975e9950f..9d6095ef4400 100644 --- a/tests/rptest/tests/e2e_finjector.py +++ b/tests/rptest/tests/e2e_finjector.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/fetch_after_deletion_test.py b/tests/rptest/tests/fetch_after_deletion_test.py index 6b9296d5cce2..15d99faf8757 100644 --- a/tests/rptest/tests/fetch_after_deletion_test.py +++ b/tests/rptest/tests/fetch_after_deletion_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/fetch_fairness_test.py b/tests/rptest/tests/fetch_fairness_test.py index dbd049afab12..4e1274383e99 100644 --- a/tests/rptest/tests/fetch_fairness_test.py +++ b/tests/rptest/tests/fetch_fairness_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/full_node_recovery_test.py b/tests/rptest/tests/full_node_recovery_test.py index a396bade6a50..cf49348fa992 100644 --- a/tests/rptest/tests/full_node_recovery_test.py +++ b/tests/rptest/tests/full_node_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/idempotency_test.py b/tests/rptest/tests/idempotency_test.py index 55007e2d0b6f..5e020a7fea4e 100644 --- a/tests/rptest/tests/idempotency_test.py +++ b/tests/rptest/tests/idempotency_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/kafka_cli_client_compat_test.py b/tests/rptest/tests/kafka_cli_client_compat_test.py index cc4203fc0192..18dfb45fd0a4 100644 --- a/tests/rptest/tests/kafka_cli_client_compat_test.py +++ b/tests/rptest/tests/kafka_cli_client_compat_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/leadership_transfer_test.py b/tests/rptest/tests/leadership_transfer_test.py index 51e8f595234e..b25ee7ee4bca 100644 --- a/tests/rptest/tests/leadership_transfer_test.py +++ b/tests/rptest/tests/leadership_transfer_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/librdkafka_test.py b/tests/rptest/tests/librdkafka_test.py index 8f6b7c24a6c9..62beaab804ea 100644 --- a/tests/rptest/tests/librdkafka_test.py +++ b/tests/rptest/tests/librdkafka_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/log_level_test.py b/tests/rptest/tests/log_level_test.py index e031f30ee1de..2f07d8ecca77 100644 --- a/tests/rptest/tests/log_level_test.py +++ b/tests/rptest/tests/log_level_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/metrics_reporter_test.py b/tests/rptest/tests/metrics_reporter_test.py index 3083ae3828e2..5e091c6a0625 100644 --- a/tests/rptest/tests/metrics_reporter_test.py +++ b/tests/rptest/tests/metrics_reporter_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/multi_restarts_with_archival_test.py b/tests/rptest/tests/multi_restarts_with_archival_test.py index 22e62648def0..9bbcde719856 100644 --- a/tests/rptest/tests/multi_restarts_with_archival_test.py +++ b/tests/rptest/tests/multi_restarts_with_archival_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/node_operations_fuzzy_test.py b/tests/rptest/tests/node_operations_fuzzy_test.py index 6c7b2c11b139..2c1c6af2242d 100644 --- a/tests/rptest/tests/node_operations_fuzzy_test.py +++ b/tests/rptest/tests/node_operations_fuzzy_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/nodes_decommissioning_test.py b/tests/rptest/tests/nodes_decommissioning_test.py index 7bb761b1c69d..7fc0a605533e 100644 --- a/tests/rptest/tests/nodes_decommissioning_test.py +++ b/tests/rptest/tests/nodes_decommissioning_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/pandaproxy_test.py b/tests/rptest/tests/pandaproxy_test.py index f3fac1df4e24..73670c9b4541 100644 --- a/tests/rptest/tests/pandaproxy_test.py +++ b/tests/rptest/tests/pandaproxy_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/partition_movement.py b/tests/rptest/tests/partition_movement.py index 8e26f71fd950..eae5b8dabd86 100644 --- a/tests/rptest/tests/partition_movement.py +++ b/tests/rptest/tests/partition_movement.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/partition_movement_test.py b/tests/rptest/tests/partition_movement_test.py index 904106fb78bf..dca726ee7b9b 100644 --- a/tests/rptest/tests/partition_movement_test.py +++ b/tests/rptest/tests/partition_movement_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/prefix_truncate_recovery_test.py b/tests/rptest/tests/prefix_truncate_recovery_test.py index 99488674b356..818d6dcb9504 100644 --- a/tests/rptest/tests/prefix_truncate_recovery_test.py +++ b/tests/rptest/tests/prefix_truncate_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/raft_availability_test.py b/tests/rptest/tests/raft_availability_test.py index d22e1fd197f9..46f46beb5d10 100644 --- a/tests/rptest/tests/raft_availability_test.py +++ b/tests/rptest/tests/raft_availability_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/recreate_topic_metadata_test.py b/tests/rptest/tests/recreate_topic_metadata_test.py index 7d66d769da03..f002dc80ea03 100644 --- a/tests/rptest/tests/recreate_topic_metadata_test.py +++ b/tests/rptest/tests/recreate_topic_metadata_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/redpanda_test.py b/tests/rptest/tests/redpanda_test.py index 879b4aad080c..48ad12d7e2f2 100644 --- a/tests/rptest/tests/redpanda_test.py +++ b/tests/rptest/tests/redpanda_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/retention_policy_test.py b/tests/rptest/tests/retention_policy_test.py index 231762fc0283..3bd231544040 100644 --- a/tests/rptest/tests/retention_policy_test.py +++ b/tests/rptest/tests/retention_policy_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/rpk_topic_test.py b/tests/rptest/tests/rpk_topic_test.py index 7c726d6680b0..336e20210b8e 100644 --- a/tests/rptest/tests/rpk_topic_test.py +++ b/tests/rptest/tests/rpk_topic_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/scaling_up_test.py b/tests/rptest/tests/scaling_up_test.py index f1237e763d78..d18a02c30d0f 100644 --- a/tests/rptest/tests/scaling_up_test.py +++ b/tests/rptest/tests/scaling_up_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/scram_pythonlib_test.py b/tests/rptest/tests/scram_pythonlib_test.py index f42a828da41d..f8b635fe46bf 100644 --- a/tests/rptest/tests/scram_pythonlib_test.py +++ b/tests/rptest/tests/scram_pythonlib_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/scram_test.py b/tests/rptest/tests/scram_test.py index 7d9d3f7067b0..811b2b96e963 100644 --- a/tests/rptest/tests/scram_test.py +++ b/tests/rptest/tests/scram_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/scramful_eos_test.py b/tests/rptest/tests/scramful_eos_test.py index dfa7fe52acd9..b0182549c012 100644 --- a/tests/rptest/tests/scramful_eos_test.py +++ b/tests/rptest/tests/scramful_eos_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/scramless_eos_test.py b/tests/rptest/tests/scramless_eos_test.py index 26a35a7f7715..bceba67776c5 100644 --- a/tests/rptest/tests/scramless_eos_test.py +++ b/tests/rptest/tests/scramless_eos_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/topic_delete_test.py b/tests/rptest/tests/topic_delete_test.py index ba3be6f941fb..80630fb4f59c 100644 --- a/tests/rptest/tests/topic_delete_test.py +++ b/tests/rptest/tests/topic_delete_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/tx_reads_writes_test.py b/tests/rptest/tests/tx_reads_writes_test.py index 124c775e3a42..79d9e7758f86 100644 --- a/tests/rptest/tests/tx_reads_writes_test.py +++ b/tests/rptest/tests/tx_reads_writes_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/tx_verifier_test.py b/tests/rptest/tests/tx_verifier_test.py index b29a74c0e225..ae7c6a36e9d1 100644 --- a/tests/rptest/tests/tx_verifier_test.py +++ b/tests/rptest/tests/tx_verifier_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wait_for_local_consumer_test.py b/tests/rptest/tests/wait_for_local_consumer_test.py index 512e47607cf6..54e0c20849f5 100644 --- a/tests/rptest/tests/wait_for_local_consumer_test.py +++ b/tests/rptest/tests/wait_for_local_consumer_test.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/util.py b/tests/rptest/util.py index b32a215ef8ad..761723f8f1df 100644 --- a/tests/rptest/util.py +++ b/tests/rptest/util.py @@ -1,4 +1,4 @@ -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tools/cmake_test.py b/tools/cmake_test.py index c6ed5cb078d2..3bacdf9fa28d 100755 --- a/tools/cmake_test.py +++ b/tools/cmake_test.py @@ -1,5 +1,5 @@ #!/usr/bin/env python3 -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tools/kafka-python-api-serde.py b/tools/kafka-python-api-serde.py index e97bbe5f7031..097b8ebe9154 100755 --- a/tools/kafka-python-api-serde.py +++ b/tools/kafka-python-api-serde.py @@ -1,5 +1,5 @@ #!/usr/bin/env python3 -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tools/rpcgen.py b/tools/rpcgen.py index 58a75c8d55da..659269a94a88 100755 --- a/tools/rpcgen.py +++ b/tools/rpcgen.py @@ -1,5 +1,5 @@ #!/usr/bin/env python3 -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tools/ts-generator/example/demo.ts b/tools/ts-generator/example/demo.ts index 6c9da049080f..9153d7c5287f 100644 --- a/tools/ts-generator/example/demo.ts +++ b/tools/ts-generator/example/demo.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/example/functions.ts b/tools/ts-generator/example/functions.ts index 36d8cf2f9c76..13baa07178e5 100644 --- a/tools/ts-generator/example/functions.ts +++ b/tools/ts-generator/example/functions.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/rpc/example/demo.ts b/tools/ts-generator/rpc/example/demo.ts index cdfe2ec0c4da..f2dbb3ad2d3f 100644 --- a/tools/ts-generator/rpc/example/demo.ts +++ b/tools/ts-generator/rpc/example/demo.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/rpc/example/functions.ts b/tools/ts-generator/rpc/example/functions.ts index 6d21929580e6..d0eed5bb22bd 100644 --- a/tools/ts-generator/rpc/example/functions.ts +++ b/tools/ts-generator/rpc/example/functions.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/rpc/example/generatedServer.ts b/tools/ts-generator/rpc/example/generatedServer.ts index 5ad0ac89262f..adf7f099107f 100644 --- a/tools/ts-generator/rpc/example/generatedServer.ts +++ b/tools/ts-generator/rpc/example/generatedServer.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/rpc/example/generatedType.ts b/tools/ts-generator/rpc/example/generatedType.ts index ee630efb55f5..68b4881b7af3 100644 --- a/tools/ts-generator/rpc/example/generatedType.ts +++ b/tools/ts-generator/rpc/example/generatedType.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/rpc/rpc_gen_js.py b/tools/ts-generator/rpc/rpc_gen_js.py index 9b896815aae5..6a8bbdcf00a3 100644 --- a/tools/ts-generator/rpc/rpc_gen_js.py +++ b/tools/ts-generator/rpc/rpc_gen_js.py @@ -1,5 +1,5 @@ #!/usr/bin/env python3 -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Licensed as a Redpanda Enterprise file under the Redpanda Community # License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/types/functions.ts b/tools/ts-generator/types/functions.ts index 46f3034af928..f397b1ac7d25 100644 --- a/tools/ts-generator/types/functions.ts +++ b/tools/ts-generator/types/functions.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/types/test.ts b/tools/ts-generator/types/test.ts index 383f28875b57..4530c1ed7173 100644 --- a/tools/ts-generator/types/test.ts +++ b/tools/ts-generator/types/test.ts @@ -1,5 +1,5 @@ /** - * Copyright 2020 Vectorized, Inc. + * Copyright 2020 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tools/ts-generator/types/types_gen_js.py b/tools/ts-generator/types/types_gen_js.py index 3bcb8d925082..0b4530a57e03 100644 --- a/tools/ts-generator/types/types_gen_js.py +++ b/tools/ts-generator/types/types_gen_js.py @@ -1,5 +1,5 @@ #!/usr/bin/env python3 -# Copyright 2020 Vectorized, Inc. +# Copyright 2020 Redpanda Data, Inc. # # Licensed as a Redpanda Enterprise file under the Redpanda Community # License (the "License"); you may not use this file except in compliance with From c2e22debf59dbc4ad91dfa8d1a9520e352b382fe Mon Sep 17 00:00:00 2001 From: Andrew Hsu Date: Mon, 21 Mar 2022 20:49:37 +0000 Subject: [PATCH 2/5] replace vectorized with redpanda in 2021 copyright find . -type f -exec sed -i 's|Copyright 2021 Vectorized, Inc.|Copyright 2021 Redpanda Data, Inc.|g' {} \; --- .github/workflows/helm-chart-release.yml | 2 +- .github/workflows/helm-chart-test.yml | 2 +- licenses/boilerplate.go.txt | 2 +- src/go/k8s/apis/redpanda/v1alpha1/cluster_types.go | 2 +- src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook.go | 2 +- src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook_test.go | 2 +- src/go/k8s/apis/redpanda/v1alpha1/groupversion_info.go | 2 +- src/go/k8s/apis/redpanda/v1alpha1/webhook_suite_test.go | 2 +- src/go/k8s/apis/redpanda/v1alpha1/zz_generated.deepcopy.go | 2 +- src/go/k8s/cmd/configurator/main.go | 2 +- src/go/k8s/controllers/redpanda/cluster_controller.go | 2 +- src/go/k8s/controllers/redpanda/cluster_controller_test.go | 2 +- src/go/k8s/controllers/redpanda/suite_test.go | 2 +- src/go/k8s/main.go | 2 +- src/go/k8s/pkg/labels/labels.go | 2 +- src/go/k8s/pkg/labels/labels_test.go | 2 +- src/go/k8s/pkg/resources/certmanager/admin_api.go | 2 +- src/go/k8s/pkg/resources/certmanager/certificate.go | 2 +- src/go/k8s/pkg/resources/certmanager/common_name.go | 2 +- src/go/k8s/pkg/resources/certmanager/common_name_test.go | 2 +- src/go/k8s/pkg/resources/certmanager/issuer.go | 2 +- src/go/k8s/pkg/resources/certmanager/kafka_api.go | 2 +- src/go/k8s/pkg/resources/certmanager/pandaproxy_api.go | 2 +- src/go/k8s/pkg/resources/certmanager/pki.go | 2 +- src/go/k8s/pkg/resources/certmanager/schemaregistry_api.go | 2 +- src/go/k8s/pkg/resources/cluster_role.go | 2 +- src/go/k8s/pkg/resources/cluster_role_binding.go | 2 +- src/go/k8s/pkg/resources/cluster_service.go | 2 +- src/go/k8s/pkg/resources/configmap.go | 2 +- src/go/k8s/pkg/resources/featuregates/shadow_indexing.go | 2 +- src/go/k8s/pkg/resources/headless_service.go | 2 +- src/go/k8s/pkg/resources/ingress.go | 2 +- src/go/k8s/pkg/resources/node_port_service.go | 2 +- src/go/k8s/pkg/resources/pdb.go | 2 +- src/go/k8s/pkg/resources/resource.go | 2 +- src/go/k8s/pkg/resources/service_account.go | 2 +- src/go/k8s/pkg/resources/statefulset.go | 2 +- src/go/k8s/pkg/resources/statefulset_test.go | 2 +- src/go/k8s/pkg/resources/statefulset_update.go | 2 +- src/go/k8s/pkg/resources/superusers.go | 2 +- src/go/rpk/Makefile | 2 +- src/go/rpk/pkg/api/admin/admin.go | 2 +- src/go/rpk/pkg/api/admin/admin_test.go | 2 +- src/go/rpk/pkg/api/admin/api_broker.go | 2 +- src/go/rpk/pkg/api/admin/api_config.go | 2 +- src/go/rpk/pkg/api/admin/api_metrics.go | 2 +- src/go/rpk/pkg/api/admin/api_node_config.go | 2 +- src/go/rpk/pkg/api/admin/api_partition.go | 2 +- src/go/rpk/pkg/api/admin/api_user.go | 2 +- src/go/rpk/pkg/cli/cmd/acl.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/common.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/common_test.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/create.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/delete.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/list.go | 2 +- src/go/rpk/pkg/cli/cmd/acl/user.go | 2 +- src/go/rpk/pkg/cli/cmd/check.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/config.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/edit.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/export.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/import.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/status.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/metadata.go | 2 +- src/go/rpk/pkg/cli/cmd/common/common.go | 2 +- src/go/rpk/pkg/cli/cmd/config.go | 2 +- src/go/rpk/pkg/cli/cmd/debug.go | 2 +- src/go/rpk/pkg/cli/cmd/debug/bundle.go | 2 +- src/go/rpk/pkg/cli/cmd/debug/bundle_test.go | 2 +- src/go/rpk/pkg/cli/cmd/debug/debug_darwin.go | 2 +- src/go/rpk/pkg/cli/cmd/debug/debug_linux.go | 2 +- src/go/rpk/pkg/cli/cmd/debug/info.go | 2 +- src/go/rpk/pkg/cli/cmd/group/describe.go | 2 +- src/go/rpk/pkg/cli/cmd/group/group.go | 2 +- src/go/rpk/pkg/cli/cmd/group/seek.go | 2 +- src/go/rpk/pkg/cli/cmd/group/seek_test.go | 2 +- src/go/rpk/pkg/cli/cmd/mode.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/admin/admin.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/admin/brokers/brokers.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/check.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/config.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/config_test.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/mode.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/mode_test.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/package.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/start.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/start_test.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/stop.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/stop_test.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/tune.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/tune/help.go | 2 +- src/go/rpk/pkg/cli/cmd/redpanda/tune_test.go | 2 +- src/go/rpk/pkg/cli/cmd/start.go | 2 +- src/go/rpk/pkg/cli/cmd/stop.go | 2 +- src/go/rpk/pkg/cli/cmd/topic.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/add_partitions.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/config.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/consume.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/create.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/delete.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/describe.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/list.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/produce.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/utils.go | 2 +- src/go/rpk/pkg/cli/cmd/topic/utils_test.go | 2 +- src/go/rpk/pkg/cli/cmd/tune.go | 2 +- src/go/rpk/pkg/system/metrics.go | 2 +- src/go/rpk/pkg/system/metrics_test.go | 2 +- src/go/rpk/pkg/system/syslog/package.go | 2 +- src/go/rpk/pkg/system/syslog/syslog.go | 2 +- src/go/rpk/pkg/tuners/ballast/tuner.go | 2 +- src/go/rpk/pkg/tuners/executors/commands/write_sized_file.go | 2 +- .../rpk/pkg/tuners/executors/commands/write_sized_file_test.go | 2 +- src/go/rpk/pkg/tuners/factory/factory.go | 2 +- src/v/archival/archival_policy.cc | 2 +- src/v/archival/archival_policy.h | 2 +- src/v/archival/fwd.h | 2 +- src/v/archival/logger.h | 2 +- src/v/archival/ntp_archiver_service.cc | 2 +- src/v/archival/ntp_archiver_service.h | 2 +- src/v/archival/probe.cc | 2 +- src/v/archival/probe.h | 2 +- src/v/archival/service.cc | 2 +- src/v/archival/service.h | 2 +- src/v/archival/tests/ntp_archiver_test.cc | 2 +- src/v/archival/tests/service_fixture.cc | 2 +- src/v/archival/tests/service_fixture.h | 2 +- src/v/archival/tests/service_test.cc | 2 +- src/v/archival/types.cc | 2 +- src/v/archival/types.h | 2 +- src/v/archival/upload_controller.cc | 2 +- src/v/archival/upload_controller.h | 2 +- src/v/cloud_storage/cache_service.cc | 2 +- src/v/cloud_storage/cache_service.h | 2 +- src/v/cloud_storage/fwd.h | 2 +- src/v/cloud_storage/logger.h | 2 +- src/v/cloud_storage/offset_translation_layer.cc | 2 +- src/v/cloud_storage/offset_translation_layer.h | 2 +- src/v/cloud_storage/probe.cc | 2 +- src/v/cloud_storage/probe.h | 2 +- src/v/cloud_storage/remote.cc | 2 +- src/v/cloud_storage/remote.h | 2 +- src/v/cloud_storage/remote_partition.cc | 2 +- src/v/cloud_storage/remote_partition.h | 2 +- src/v/cloud_storage/tests/cache_test.cc | 2 +- src/v/cloud_storage/tests/cache_test_fixture.h | 2 +- src/v/cloud_storage/tests/cloud_storage_fixture.h | 2 +- src/v/cloud_storage/tests/directory_walker_test.cc | 2 +- src/v/cloud_storage/tests/offset_translation_layer_test.cc | 2 +- src/v/cloud_storage/tests/remote_partition_test.cc | 2 +- src/v/cloud_storage/tests/remote_segment_test.cc | 2 +- src/v/cloud_storage/tests/remote_test.cc | 2 +- src/v/cloud_storage/tests/s3_imposter.cc | 2 +- src/v/cloud_storage/tests/s3_imposter.h | 2 +- src/v/cloud_storage/tests/topic_manifest_test.cc | 2 +- src/v/cluster/archival_metadata_stm.cc | 2 +- src/v/cluster/archival_metadata_stm.h | 2 +- src/v/cluster/config_frontend.cc | 2 +- src/v/cluster/config_frontend.h | 2 +- src/v/cluster/config_manager.cc | 2 +- src/v/cluster/config_manager.h | 2 +- src/v/cluster/data_policy_frontend.cc | 2 +- src/v/cluster/data_policy_frontend.h | 2 +- src/v/cluster/data_policy_manager.cc | 2 +- src/v/cluster/data_policy_manager.h | 2 +- src/v/cluster/feature_manager.h | 2 +- src/v/cluster/feature_table.cc | 2 +- src/v/cluster/health_manager.cc | 2 +- src/v/cluster/health_manager.h | 2 +- src/v/cluster/metrics_reporter.cc | 2 +- src/v/cluster/node/local_monitor.cc | 2 +- src/v/cluster/node/local_monitor.h | 2 +- src/v/cluster/node/types.cc | 2 +- src/v/cluster/node/types.h | 2 +- src/v/cluster/non_replicable_topics_frontend.cc | 2 +- src/v/cluster/non_replicable_topics_frontend.h | 2 +- src/v/cluster/scheduling/leader_balancer_greedy.h | 2 +- src/v/cluster/security_manager.h | 2 +- src/v/cluster/tests/data_policy_controller_test.cc | 2 +- src/v/cluster/tests/leader_balancer_test.cc | 2 +- src/v/cluster/tests/metrics_reporter_test.cc | 2 +- src/v/cluster/tests/topic_configuration_compat_test.cc | 2 +- src/v/config/broker_endpoint.h | 2 +- src/v/config/convert.h | 2 +- src/v/config/node_config.cc | 2 +- src/v/config/node_config.h | 2 +- src/v/coproc/api.cc | 2 +- src/v/coproc/event_handler.cc | 2 +- src/v/coproc/event_handler.h | 2 +- src/v/coproc/exception.h | 2 +- src/v/coproc/fwd.h | 2 +- src/v/coproc/partition.cc | 2 +- src/v/coproc/partition.h | 2 +- src/v/coproc/partition_manager.cc | 2 +- src/v/coproc/partition_manager.h | 2 +- src/v/coproc/reconciliation_backend.cc | 2 +- src/v/coproc/reconciliation_backend.h | 2 +- src/v/coproc/reference_window_consumer.hpp | 2 +- src/v/coproc/script_context_backend.cc | 2 +- src/v/coproc/script_context_backend.h | 2 +- src/v/coproc/script_context_frontend.cc | 2 +- src/v/coproc/script_context_frontend.h | 2 +- src/v/coproc/script_context_router.cc | 2 +- src/v/coproc/script_context_router.h | 2 +- src/v/coproc/script_database.h | 2 +- src/v/coproc/sys_refs.h | 2 +- src/v/coproc/tests/event_handler_tests.cc | 2 +- src/v/coproc/tests/fixtures/coproc_cluster_fixture.cc | 2 +- src/v/coproc/tests/fixtures/coproc_cluster_fixture.h | 2 +- src/v/coproc/tests/fixtures/fiber_mock_fixture.cc | 2 +- src/v/coproc/tests/fixtures/fiber_mock_fixture.h | 2 +- src/v/coproc/tests/partition_movement_tests.cc | 2 +- src/v/coproc/tests/topic_ingestion_policy_tests.cc | 2 +- src/v/coproc/tests/utils/batch_utils.cc | 2 +- src/v/coproc/tests/utils/batch_utils.h | 2 +- src/v/coproc/tests/utils/kafka_publish_consumer.h | 2 +- src/v/hashing/crc32.h | 2 +- src/v/kafka/client/client_fetch_batch_reader.cc | 2 +- src/v/kafka/client/client_fetch_batch_reader.h | 2 +- src/v/kafka/client/fetch_session.h | 2 +- src/v/kafka/client/fwd.h | 2 +- src/v/kafka/client/partitioners.cc | 2 +- src/v/kafka/client/partitioners.h | 2 +- src/v/kafka/client/sasl_client.cc | 2 +- src/v/kafka/client/sasl_client.h | 2 +- src/v/kafka/client/test/retry.cc | 2 +- src/v/kafka/client/types.h | 2 +- src/v/kafka/group_probe.h | 2 +- src/v/kafka/latency_probe.h | 2 +- src/v/kafka/protocol/legacy_message.h | 2 +- src/v/kafka/server/errors.h | 2 +- src/v/kafka/server/handlers/add_offsets_to_txn.h | 2 +- src/v/kafka/server/handlers/add_partitions_to_txn.h | 2 +- src/v/kafka/server/handlers/alter_configs.h | 2 +- src/v/kafka/server/handlers/api_versions.h | 2 +- src/v/kafka/server/handlers/configs/config_utils.h | 2 +- src/v/kafka/server/handlers/create_acls.cc | 2 +- src/v/kafka/server/handlers/create_acls.h | 2 +- src/v/kafka/server/handlers/create_partitions.h | 2 +- src/v/kafka/server/handlers/create_topics.h | 2 +- src/v/kafka/server/handlers/delete_acls.cc | 2 +- src/v/kafka/server/handlers/delete_acls.h | 2 +- src/v/kafka/server/handlers/delete_groups.h | 2 +- src/v/kafka/server/handlers/delete_topics.h | 2 +- src/v/kafka/server/handlers/describe_acls.cc | 2 +- src/v/kafka/server/handlers/describe_acls.h | 2 +- src/v/kafka/server/handlers/describe_configs.h | 2 +- src/v/kafka/server/handlers/describe_groups.h | 2 +- src/v/kafka/server/handlers/describe_log_dirs.cc | 2 +- src/v/kafka/server/handlers/describe_log_dirs.h | 2 +- src/v/kafka/server/handlers/details/data_policy.h | 2 +- src/v/kafka/server/handlers/details/leader_epoch.h | 2 +- src/v/kafka/server/handlers/details/security.h | 2 +- src/v/kafka/server/handlers/end_txn.h | 2 +- src/v/kafka/server/handlers/fetch.h | 2 +- src/v/kafka/server/handlers/find_coordinator.h | 2 +- src/v/kafka/server/handlers/handler.h | 2 +- src/v/kafka/server/handlers/handlers.h | 2 +- src/v/kafka/server/handlers/heartbeat.h | 2 +- src/v/kafka/server/handlers/incremental_alter_configs.h | 2 +- src/v/kafka/server/handlers/init_producer_id.h | 2 +- src/v/kafka/server/handlers/join_group.h | 2 +- src/v/kafka/server/handlers/leave_group.h | 2 +- src/v/kafka/server/handlers/list_groups.h | 2 +- src/v/kafka/server/handlers/list_offsets.h | 2 +- src/v/kafka/server/handlers/metadata.h | 2 +- src/v/kafka/server/handlers/offset_commit.h | 2 +- src/v/kafka/server/handlers/offset_fetch.h | 2 +- src/v/kafka/server/handlers/offset_for_leader_epoch.h | 2 +- src/v/kafka/server/handlers/produce.h | 2 +- src/v/kafka/server/handlers/sasl_authenticate.h | 2 +- src/v/kafka/server/handlers/sasl_handshake.h | 2 +- src/v/kafka/server/handlers/sync_group.h | 2 +- src/v/kafka/server/handlers/txn_offset_commit.h | 2 +- src/v/kafka/server/materialized_partition.h | 2 +- src/v/kafka/server/partition_proxy.cc | 2 +- src/v/kafka/server/partition_proxy.h | 2 +- src/v/kafka/server/queue_depth_monitor.h | 2 +- src/v/kafka/server/replicated_partition.cc | 2 +- src/v/kafka/server/replicated_partition.h | 2 +- src/v/net/fwd.h | 2 +- src/v/net/tls.cc | 2 +- src/v/net/tls.h | 2 +- src/v/net/transport.h | 2 +- src/v/net/types.h | 2 +- src/v/pandaproxy/error.cc | 2 +- src/v/pandaproxy/error.h | 2 +- src/v/pandaproxy/json/error.cc | 2 +- src/v/pandaproxy/json/error.h | 2 +- src/v/pandaproxy/json/exceptions.h | 2 +- src/v/pandaproxy/json/requests/brokers.h | 2 +- src/v/pandaproxy/json/rjson_parse.h | 2 +- src/v/pandaproxy/parsing/error.cc | 2 +- src/v/pandaproxy/parsing/error.h | 2 +- src/v/pandaproxy/parsing/exceptions.h | 2 +- src/v/pandaproxy/parsing/from_chars.h | 2 +- src/v/pandaproxy/parsing/httpd.h | 2 +- src/v/pandaproxy/parsing/test/from_chars.cc | 2 +- src/v/pandaproxy/parsing/test/httpd.cc | 2 +- src/v/pandaproxy/schema_registry/api.cc | 2 +- src/v/pandaproxy/schema_registry/api.h | 2 +- src/v/pandaproxy/schema_registry/avro.cc | 2 +- src/v/pandaproxy/schema_registry/avro.h | 2 +- src/v/pandaproxy/schema_registry/configuration.cc | 2 +- src/v/pandaproxy/schema_registry/configuration.h | 2 +- src/v/pandaproxy/schema_registry/error.cc | 2 +- src/v/pandaproxy/schema_registry/error.h | 2 +- src/v/pandaproxy/schema_registry/errors.h | 2 +- src/v/pandaproxy/schema_registry/exceptions.h | 2 +- src/v/pandaproxy/schema_registry/fwd.h | 2 +- src/v/pandaproxy/schema_registry/handlers.cc | 2 +- src/v/pandaproxy/schema_registry/handlers.h | 2 +- src/v/pandaproxy/schema_registry/protobuf.cc | 2 +- src/v/pandaproxy/schema_registry/protobuf.h | 2 +- src/v/pandaproxy/schema_registry/requests/compatibility.h | 2 +- src/v/pandaproxy/schema_registry/requests/config.h | 2 +- src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id.h | 2 +- .../schema_registry/requests/get_schemas_ids_id_versions.h | 2 +- .../schema_registry/requests/get_subject_versions_version.h | 2 +- .../pandaproxy/schema_registry/requests/post_subject_versions.h | 2 +- .../requests/test/get_subject_versions_version.cc | 2 +- .../schema_registry/requests/test/post_subject_versions.cc | 2 +- src/v/pandaproxy/schema_registry/seq_writer.cc | 2 +- src/v/pandaproxy/schema_registry/seq_writer.h | 2 +- src/v/pandaproxy/schema_registry/service.cc | 2 +- src/v/pandaproxy/schema_registry/service.h | 2 +- src/v/pandaproxy/schema_registry/sharded_store.cc | 2 +- src/v/pandaproxy/schema_registry/sharded_store.h | 2 +- src/v/pandaproxy/schema_registry/storage.h | 2 +- src/v/pandaproxy/schema_registry/store.h | 2 +- src/v/pandaproxy/schema_registry/test/avro_payloads.h | 2 +- src/v/pandaproxy/schema_registry/test/client_utils.h | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_3rdparty.cc | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_avro.cc | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_avro.h | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_protobuf.cc | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_protobuf.h | 2 +- src/v/pandaproxy/schema_registry/test/compatibility_store.cc | 2 +- src/v/pandaproxy/schema_registry/test/consume_to_store.cc | 2 +- src/v/pandaproxy/schema_registry/test/one_shot.cc | 2 +- src/v/pandaproxy/schema_registry/test/sanitize_avro.cc | 2 +- src/v/pandaproxy/schema_registry/test/sharded_store.cc | 2 +- src/v/pandaproxy/schema_registry/test/storage.cc | 2 +- src/v/pandaproxy/schema_registry/test/store.cc | 2 +- src/v/pandaproxy/schema_registry/test/util.cc | 2 +- src/v/pandaproxy/schema_registry/types.cc | 2 +- src/v/pandaproxy/schema_registry/types.h | 2 +- src/v/pandaproxy/schema_registry/util.h | 2 +- src/v/raft/offset_translator.cc | 2 +- src/v/raft/offset_translator.h | 2 +- src/v/reflection/absl/btree_map.h | 2 +- src/v/reflection/absl/flat_hash_map.h | 2 +- src/v/reflection/absl/node_hash_map.h | 2 +- src/v/reflection/seastar/circular_buffer.h | 2 +- src/v/reflection/std/map.h | 2 +- src/v/reflection/std/unordered_map.h | 2 +- src/v/reflection/std/vector.h | 2 +- src/v/rpc/fwd.h | 2 +- src/v/security/acl.h | 2 +- src/v/security/acl_store.cc | 2 +- src/v/security/acl_store.h | 2 +- src/v/security/authorizer.h | 2 +- src/v/security/scram_credential.cc | 2 +- src/v/security/scram_credential.h | 2 +- src/v/serde/envelope.h | 2 +- src/v/serde/envelope_for_each_field.h | 2 +- src/v/serde/logger.h | 2 +- src/v/serde/serde.h | 2 +- src/v/serde/serde_exception.h | 2 +- src/v/serde/test/serde_test.cc | 2 +- src/v/serde/type_str.h | 2 +- src/v/storage/index_state_serde_compat.h | 2 +- src/v/storage/offset_translator_state.cc | 2 +- src/v/storage/offset_translator_state.h | 2 +- src/v/storage/translating_reader.h | 2 +- src/v/utils/ema.h | 2 +- src/v/utils/gate_guard.h | 2 +- src/v/utils/moving_average.h | 2 +- src/v/utils/prefix_logger.h | 2 +- src/v/utils/stream_utils.h | 2 +- src/v/utils/tests/fragmented_vector_test.cc | 2 +- src/v/utils/tests/human_test.cc | 2 +- src/v/utils/tests/input_stream_fanout_test.cc | 2 +- src/v/v8_engine/data_policy.cc | 2 +- src/v/v8_engine/data_policy.h | 2 +- src/v/v8_engine/data_policy_table.cc | 2 +- src/v/v8_engine/data_policy_table.h | 2 +- src/v/v8_engine/fwd.h | 2 +- src/v/v8_engine/internal/environment.cc | 2 +- src/v/v8_engine/internal/environment.h | 2 +- src/v/v8_engine/internal/executor.cc | 2 +- src/v/v8_engine/internal/executor.h | 2 +- src/v/v8_engine/internal/script.cc | 2 +- src/v/v8_engine/internal/script.h | 2 +- src/v/v8_engine/internal/tests/executor_test.cc | 2 +- src/v/v8_engine/internal/tests/script_test.cc | 2 +- tests/rptest/clients/kcl.py | 2 +- tests/rptest/clients/rpk_remote.py | 2 +- tests/rptest/clients/types.py | 2 +- tests/rptest/services/admin.py | 2 +- tests/rptest/services/cluster.py | 2 +- tests/rptest/services/compatibility/example_base.py | 2 +- tests/rptest/services/compatibility/example_runner.py | 2 +- tests/rptest/services/compatibility/franzgo_examples.py | 2 +- tests/rptest/services/compatibility/kafka_streams_examples.py | 2 +- tests/rptest/services/compatibility/sarama_examples.py | 2 +- tests/rptest/services/honey_badger.py | 2 +- tests/rptest/test_suite_rpk.yml | 2 +- tests/rptest/tests/acls_test.py | 2 +- tests/rptest/tests/archival_test.py | 2 +- tests/rptest/tests/bytes_sent_test.py | 2 +- tests/rptest/tests/cluster_features_test.py | 2 +- tests/rptest/tests/compatibility/franzgo_test.py | 2 +- tests/rptest/tests/compatibility/kafka_streams_test.py | 2 +- tests/rptest/tests/compatibility/sarama_test.py | 2 +- tests/rptest/tests/data_policy_test.py | 2 +- tests/rptest/tests/e2e_shadow_indexing_test.py | 2 +- tests/rptest/tests/group_membership_test.py | 2 +- tests/rptest/tests/offset_for_leader_epoch_archival_test.py | 2 +- tests/rptest/tests/offset_for_leader_epoch_test.py | 2 +- tests/rptest/tests/partition_metrics_test.py | 2 +- tests/rptest/tests/resource_limits_test.py | 2 +- tests/rptest/tests/rpk_cluster_test.py | 2 +- tests/rptest/tests/rpk_config_test.py | 2 +- tests/rptest/tests/schema_registry_test.py | 2 +- tests/rptest/tests/shadow_indexing_tx_test.py | 2 +- tests/rptest/tests/topic_autocreate_test.py | 2 +- tests/rptest/tests/topic_recovery_test.py | 2 +- tests/rptest/tests/tx_admin_api_test.py | 2 +- tests/rptest/tests/wasm_filter_test.py | 2 +- tests/rptest/tests/wasm_identity_test.py | 2 +- tests/rptest/tests/wasm_partition_movement_test.py | 2 +- tests/rptest/tests/wasm_redpanda_failure_recovery_test.py | 2 +- tests/rptest/tests/wasm_topics_test.py | 2 +- tests/rptest/wasm/background_task.py | 2 +- tests/rptest/wasm/native_kafka_consumer.py | 2 +- tests/rptest/wasm/topic.py | 2 +- tests/rptest/wasm/topics_result_set.py | 2 +- tests/rptest/wasm/wasm_build_tool.py | 2 +- tests/rptest/wasm/wasm_script.py | 2 +- tests/rptest/wasm/wasm_test.py | 2 +- tools/gen_coverage.py | 2 +- 443 files changed, 443 insertions(+), 443 deletions(-) diff --git a/.github/workflows/helm-chart-release.yml b/.github/workflows/helm-chart-release.yml index d6f489846f5a..8f94b021596a 100644 --- a/.github/workflows/helm-chart-release.yml +++ b/.github/workflows/helm-chart-release.yml @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/.github/workflows/helm-chart-test.yml b/.github/workflows/helm-chart-test.yml index 988ebd693309..70c405e10ca3 100644 --- a/.github/workflows/helm-chart-test.yml +++ b/.github/workflows/helm-chart-test.yml @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/licenses/boilerplate.go.txt b/licenses/boilerplate.go.txt index dd4b55c33df0..3eafabb16bb5 100644 --- a/licenses/boilerplate.go.txt +++ b/licenses/boilerplate.go.txt @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/cluster_types.go b/src/go/k8s/apis/redpanda/v1alpha1/cluster_types.go index 7d62da571dff..3f48a656f006 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/cluster_types.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/cluster_types.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook.go b/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook.go index 135be9beaa8c..07f7e33a70c8 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook_test.go b/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook_test.go index c967d7e14bd8..a21501f8f584 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook_test.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/cluster_webhook_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/groupversion_info.go b/src/go/k8s/apis/redpanda/v1alpha1/groupversion_info.go index 1db44503e696..f6a10d9653ca 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/groupversion_info.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/groupversion_info.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/webhook_suite_test.go b/src/go/k8s/apis/redpanda/v1alpha1/webhook_suite_test.go index 59ddc11e0a57..3b6cf147ac6f 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/webhook_suite_test.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/webhook_suite_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/apis/redpanda/v1alpha1/zz_generated.deepcopy.go b/src/go/k8s/apis/redpanda/v1alpha1/zz_generated.deepcopy.go index a981b6528ace..e7596cb0bf49 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/zz_generated.deepcopy.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/zz_generated.deepcopy.go @@ -1,7 +1,7 @@ //go:build !ignore_autogenerated // +build !ignore_autogenerated -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/cmd/configurator/main.go b/src/go/k8s/cmd/configurator/main.go index 5224e0ec625a..4a72ed8c3872 100644 --- a/src/go/k8s/cmd/configurator/main.go +++ b/src/go/k8s/cmd/configurator/main.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/controllers/redpanda/cluster_controller.go b/src/go/k8s/controllers/redpanda/cluster_controller.go index b94ddb14a77e..23c79bbba22b 100644 --- a/src/go/k8s/controllers/redpanda/cluster_controller.go +++ b/src/go/k8s/controllers/redpanda/cluster_controller.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/controllers/redpanda/cluster_controller_test.go b/src/go/k8s/controllers/redpanda/cluster_controller_test.go index 22575e656c5a..f5036c91b85f 100644 --- a/src/go/k8s/controllers/redpanda/cluster_controller_test.go +++ b/src/go/k8s/controllers/redpanda/cluster_controller_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/controllers/redpanda/suite_test.go b/src/go/k8s/controllers/redpanda/suite_test.go index bbeb42780a15..58b13250e2aa 100644 --- a/src/go/k8s/controllers/redpanda/suite_test.go +++ b/src/go/k8s/controllers/redpanda/suite_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/main.go b/src/go/k8s/main.go index 49016c61ec01..f078d6c68ea4 100644 --- a/src/go/k8s/main.go +++ b/src/go/k8s/main.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/labels/labels.go b/src/go/k8s/pkg/labels/labels.go index f105bb9dfa2b..cadcd645c011 100644 --- a/src/go/k8s/pkg/labels/labels.go +++ b/src/go/k8s/pkg/labels/labels.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/labels/labels_test.go b/src/go/k8s/pkg/labels/labels_test.go index 4b82de5ce5b4..e086ce5cba16 100644 --- a/src/go/k8s/pkg/labels/labels_test.go +++ b/src/go/k8s/pkg/labels/labels_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/admin_api.go b/src/go/k8s/pkg/resources/certmanager/admin_api.go index de929d23696e..1f5c883d6aef 100644 --- a/src/go/k8s/pkg/resources/certmanager/admin_api.go +++ b/src/go/k8s/pkg/resources/certmanager/admin_api.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/certificate.go b/src/go/k8s/pkg/resources/certmanager/certificate.go index 6bb867230b72..b8c81c5d3e29 100644 --- a/src/go/k8s/pkg/resources/certmanager/certificate.go +++ b/src/go/k8s/pkg/resources/certmanager/certificate.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/common_name.go b/src/go/k8s/pkg/resources/certmanager/common_name.go index a44c2a367784..c700f3e5b4c8 100644 --- a/src/go/k8s/pkg/resources/certmanager/common_name.go +++ b/src/go/k8s/pkg/resources/certmanager/common_name.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/common_name_test.go b/src/go/k8s/pkg/resources/certmanager/common_name_test.go index 587fa73e36ca..ca6620ac4737 100644 --- a/src/go/k8s/pkg/resources/certmanager/common_name_test.go +++ b/src/go/k8s/pkg/resources/certmanager/common_name_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/issuer.go b/src/go/k8s/pkg/resources/certmanager/issuer.go index 552d26e4f151..60241831f36c 100644 --- a/src/go/k8s/pkg/resources/certmanager/issuer.go +++ b/src/go/k8s/pkg/resources/certmanager/issuer.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/kafka_api.go b/src/go/k8s/pkg/resources/certmanager/kafka_api.go index 9302b4902866..d16af820f0ac 100644 --- a/src/go/k8s/pkg/resources/certmanager/kafka_api.go +++ b/src/go/k8s/pkg/resources/certmanager/kafka_api.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/pandaproxy_api.go b/src/go/k8s/pkg/resources/certmanager/pandaproxy_api.go index 184b42419586..895adcc7318a 100644 --- a/src/go/k8s/pkg/resources/certmanager/pandaproxy_api.go +++ b/src/go/k8s/pkg/resources/certmanager/pandaproxy_api.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/pki.go b/src/go/k8s/pkg/resources/certmanager/pki.go index 75de845ff9e4..ff94374b9279 100644 --- a/src/go/k8s/pkg/resources/certmanager/pki.go +++ b/src/go/k8s/pkg/resources/certmanager/pki.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/certmanager/schemaregistry_api.go b/src/go/k8s/pkg/resources/certmanager/schemaregistry_api.go index 79dfc2054576..2e3a44272175 100644 --- a/src/go/k8s/pkg/resources/certmanager/schemaregistry_api.go +++ b/src/go/k8s/pkg/resources/certmanager/schemaregistry_api.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/cluster_role.go b/src/go/k8s/pkg/resources/cluster_role.go index ac5182b69d37..861e89968f8f 100644 --- a/src/go/k8s/pkg/resources/cluster_role.go +++ b/src/go/k8s/pkg/resources/cluster_role.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/cluster_role_binding.go b/src/go/k8s/pkg/resources/cluster_role_binding.go index 1dd82df457f2..a254a688288d 100644 --- a/src/go/k8s/pkg/resources/cluster_role_binding.go +++ b/src/go/k8s/pkg/resources/cluster_role_binding.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/cluster_service.go b/src/go/k8s/pkg/resources/cluster_service.go index 54bacaf8a3b7..9d4930b7dc37 100644 --- a/src/go/k8s/pkg/resources/cluster_service.go +++ b/src/go/k8s/pkg/resources/cluster_service.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/configmap.go b/src/go/k8s/pkg/resources/configmap.go index 1ee060f93dea..a190c6c1b362 100644 --- a/src/go/k8s/pkg/resources/configmap.go +++ b/src/go/k8s/pkg/resources/configmap.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/featuregates/shadow_indexing.go b/src/go/k8s/pkg/resources/featuregates/shadow_indexing.go index 3b5d81e63eee..48eab880f5e8 100644 --- a/src/go/k8s/pkg/resources/featuregates/shadow_indexing.go +++ b/src/go/k8s/pkg/resources/featuregates/shadow_indexing.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/headless_service.go b/src/go/k8s/pkg/resources/headless_service.go index 1984366da35b..8a94aa0e7e7c 100644 --- a/src/go/k8s/pkg/resources/headless_service.go +++ b/src/go/k8s/pkg/resources/headless_service.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/ingress.go b/src/go/k8s/pkg/resources/ingress.go index 0d1838ee24e5..6c0ebdbbb425 100644 --- a/src/go/k8s/pkg/resources/ingress.go +++ b/src/go/k8s/pkg/resources/ingress.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/node_port_service.go b/src/go/k8s/pkg/resources/node_port_service.go index 2bd3027a7f6b..dc37bc886391 100644 --- a/src/go/k8s/pkg/resources/node_port_service.go +++ b/src/go/k8s/pkg/resources/node_port_service.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/pdb.go b/src/go/k8s/pkg/resources/pdb.go index 28d6508ed4de..8cfa8ac178ab 100644 --- a/src/go/k8s/pkg/resources/pdb.go +++ b/src/go/k8s/pkg/resources/pdb.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/resource.go b/src/go/k8s/pkg/resources/resource.go index 7f1837223364..0ff7d6b48a68 100644 --- a/src/go/k8s/pkg/resources/resource.go +++ b/src/go/k8s/pkg/resources/resource.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/service_account.go b/src/go/k8s/pkg/resources/service_account.go index e23f5b68e0d7..bbda73d74305 100644 --- a/src/go/k8s/pkg/resources/service_account.go +++ b/src/go/k8s/pkg/resources/service_account.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/statefulset.go b/src/go/k8s/pkg/resources/statefulset.go index 9541a0b792a5..f99fdc453808 100644 --- a/src/go/k8s/pkg/resources/statefulset.go +++ b/src/go/k8s/pkg/resources/statefulset.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/statefulset_test.go b/src/go/k8s/pkg/resources/statefulset_test.go index 1eae3de816b5..77579be416bc 100644 --- a/src/go/k8s/pkg/resources/statefulset_test.go +++ b/src/go/k8s/pkg/resources/statefulset_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/statefulset_update.go b/src/go/k8s/pkg/resources/statefulset_update.go index d11be009eca6..7a6cd85a64f4 100644 --- a/src/go/k8s/pkg/resources/statefulset_update.go +++ b/src/go/k8s/pkg/resources/statefulset_update.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/superusers.go b/src/go/k8s/pkg/resources/superusers.go index a2bcbaa74534..054a4b4de099 100644 --- a/src/go/k8s/pkg/resources/superusers.go +++ b/src/go/k8s/pkg/resources/superusers.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/Makefile b/src/go/rpk/Makefile index 581991497530..27fb16ed6bb4 100644 --- a/src/go/rpk/Makefile +++ b/src/go/rpk/Makefile @@ -1,5 +1,5 @@ # Author 2021 Per Buer -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/admin.go b/src/go/rpk/pkg/api/admin/admin.go index 0b902676c5a3..3f342713188a 100644 --- a/src/go/rpk/pkg/api/admin/admin.go +++ b/src/go/rpk/pkg/api/admin/admin.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/admin_test.go b/src/go/rpk/pkg/api/admin/admin_test.go index f9bf6cdeddb8..ec32b4928424 100644 --- a/src/go/rpk/pkg/api/admin/admin_test.go +++ b/src/go/rpk/pkg/api/admin/admin_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_broker.go b/src/go/rpk/pkg/api/admin/api_broker.go index ed073117239c..057f7cca2baf 100644 --- a/src/go/rpk/pkg/api/admin/api_broker.go +++ b/src/go/rpk/pkg/api/admin/api_broker.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_config.go b/src/go/rpk/pkg/api/admin/api_config.go index 2d40d9445188..74521d0f1f92 100644 --- a/src/go/rpk/pkg/api/admin/api_config.go +++ b/src/go/rpk/pkg/api/admin/api_config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_metrics.go b/src/go/rpk/pkg/api/admin/api_metrics.go index ce8fe2f17c17..732820f3af45 100644 --- a/src/go/rpk/pkg/api/admin/api_metrics.go +++ b/src/go/rpk/pkg/api/admin/api_metrics.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_node_config.go b/src/go/rpk/pkg/api/admin/api_node_config.go index 0b817fe591a6..73d87cde9a7e 100644 --- a/src/go/rpk/pkg/api/admin/api_node_config.go +++ b/src/go/rpk/pkg/api/admin/api_node_config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_partition.go b/src/go/rpk/pkg/api/admin/api_partition.go index f9564c64f7e9..c40ef7c75039 100644 --- a/src/go/rpk/pkg/api/admin/api_partition.go +++ b/src/go/rpk/pkg/api/admin/api_partition.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/api/admin/api_user.go b/src/go/rpk/pkg/api/admin/api_user.go index f62c45bb2c31..86ef06fae083 100644 --- a/src/go/rpk/pkg/api/admin/api_user.go +++ b/src/go/rpk/pkg/api/admin/api_user.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl.go b/src/go/rpk/pkg/cli/cmd/acl.go index e0cf0e930df5..62379395a343 100644 --- a/src/go/rpk/pkg/cli/cmd/acl.go +++ b/src/go/rpk/pkg/cli/cmd/acl.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/common.go b/src/go/rpk/pkg/cli/cmd/acl/common.go index dad58a9d128c..99e6fc7fca6c 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/common.go +++ b/src/go/rpk/pkg/cli/cmd/acl/common.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/common_test.go b/src/go/rpk/pkg/cli/cmd/acl/common_test.go index 5530aefda258..f0ad1ce826e3 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/common_test.go +++ b/src/go/rpk/pkg/cli/cmd/acl/common_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/create.go b/src/go/rpk/pkg/cli/cmd/acl/create.go index fc537be67258..5cc31654635d 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/create.go +++ b/src/go/rpk/pkg/cli/cmd/acl/create.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/delete.go b/src/go/rpk/pkg/cli/cmd/acl/delete.go index ed67eb6a3924..9de555064f66 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/delete.go +++ b/src/go/rpk/pkg/cli/cmd/acl/delete.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/list.go b/src/go/rpk/pkg/cli/cmd/acl/list.go index 4fbf1eb1358d..55a35283cde3 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/list.go +++ b/src/go/rpk/pkg/cli/cmd/acl/list.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/acl/user.go b/src/go/rpk/pkg/cli/cmd/acl/user.go index 371e6e90e3cc..33aa2176ba41 100644 --- a/src/go/rpk/pkg/cli/cmd/acl/user.go +++ b/src/go/rpk/pkg/cli/cmd/acl/user.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/check.go b/src/go/rpk/pkg/cli/cmd/check.go index 60eb315eb790..adc7123feae2 100644 --- a/src/go/rpk/pkg/cli/cmd/check.go +++ b/src/go/rpk/pkg/cli/cmd/check.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster.go b/src/go/rpk/pkg/cli/cmd/cluster.go index 958d644bed8e..2003161d6fa4 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster.go +++ b/src/go/rpk/pkg/cli/cmd/cluster.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/config.go b/src/go/rpk/pkg/cli/cmd/cluster/config/config.go index 9d8a39e0d684..938932c17223 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/config.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/edit.go b/src/go/rpk/pkg/cli/cmd/cluster/config/edit.go index eedf8b5ded8e..8f183778ac7a 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/edit.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/edit.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/export.go b/src/go/rpk/pkg/cli/cmd/cluster/config/export.go index b3cbe5d1f562..0b630d0640a6 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/export.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/export.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/import.go b/src/go/rpk/pkg/cli/cmd/cluster/config/import.go index 5815ea7293d3..ab93826abdc1 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/import.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/import.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/status.go b/src/go/rpk/pkg/cli/cmd/cluster/config/status.go index 6f6eab6ec492..4c562bb53c34 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/status.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/status.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/metadata.go b/src/go/rpk/pkg/cli/cmd/cluster/metadata.go index 444a92d93b99..ca9b933dec81 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/metadata.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/metadata.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/common/common.go b/src/go/rpk/pkg/cli/cmd/common/common.go index 361e4e52fc64..72b3807731f4 100644 --- a/src/go/rpk/pkg/cli/cmd/common/common.go +++ b/src/go/rpk/pkg/cli/cmd/common/common.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/config.go b/src/go/rpk/pkg/cli/cmd/config.go index c883b4767823..6061658cce7e 100644 --- a/src/go/rpk/pkg/cli/cmd/config.go +++ b/src/go/rpk/pkg/cli/cmd/config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug.go b/src/go/rpk/pkg/cli/cmd/debug.go index 1f9949c8b833..663086c289fd 100644 --- a/src/go/rpk/pkg/cli/cmd/debug.go +++ b/src/go/rpk/pkg/cli/cmd/debug.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug/bundle.go b/src/go/rpk/pkg/cli/cmd/debug/bundle.go index 99c36f9847b5..f9b482c10b04 100644 --- a/src/go/rpk/pkg/cli/cmd/debug/bundle.go +++ b/src/go/rpk/pkg/cli/cmd/debug/bundle.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug/bundle_test.go b/src/go/rpk/pkg/cli/cmd/debug/bundle_test.go index 2f4f57fa1a1f..ec61c5897cf3 100644 --- a/src/go/rpk/pkg/cli/cmd/debug/bundle_test.go +++ b/src/go/rpk/pkg/cli/cmd/debug/bundle_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug/debug_darwin.go b/src/go/rpk/pkg/cli/cmd/debug/debug_darwin.go index 3ea0701187c2..0d985a6f003b 100644 --- a/src/go/rpk/pkg/cli/cmd/debug/debug_darwin.go +++ b/src/go/rpk/pkg/cli/cmd/debug/debug_darwin.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug/debug_linux.go b/src/go/rpk/pkg/cli/cmd/debug/debug_linux.go index fa414f427383..093e9f6c8615 100644 --- a/src/go/rpk/pkg/cli/cmd/debug/debug_linux.go +++ b/src/go/rpk/pkg/cli/cmd/debug/debug_linux.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/debug/info.go b/src/go/rpk/pkg/cli/cmd/debug/info.go index 5cd9b2fa7955..20ca0102fc22 100644 --- a/src/go/rpk/pkg/cli/cmd/debug/info.go +++ b/src/go/rpk/pkg/cli/cmd/debug/info.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/group/describe.go b/src/go/rpk/pkg/cli/cmd/group/describe.go index 2be8900caea9..31b24867430f 100644 --- a/src/go/rpk/pkg/cli/cmd/group/describe.go +++ b/src/go/rpk/pkg/cli/cmd/group/describe.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/group/group.go b/src/go/rpk/pkg/cli/cmd/group/group.go index d1204be56f3c..b82fea58d3cb 100644 --- a/src/go/rpk/pkg/cli/cmd/group/group.go +++ b/src/go/rpk/pkg/cli/cmd/group/group.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/group/seek.go b/src/go/rpk/pkg/cli/cmd/group/seek.go index 271ed8299d60..eebe3fc6b63c 100644 --- a/src/go/rpk/pkg/cli/cmd/group/seek.go +++ b/src/go/rpk/pkg/cli/cmd/group/seek.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/group/seek_test.go b/src/go/rpk/pkg/cli/cmd/group/seek_test.go index 20c1d7a962af..b30dc17c81ea 100644 --- a/src/go/rpk/pkg/cli/cmd/group/seek_test.go +++ b/src/go/rpk/pkg/cli/cmd/group/seek_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/mode.go b/src/go/rpk/pkg/cli/cmd/mode.go index faa8488c28b1..a300c74111a2 100644 --- a/src/go/rpk/pkg/cli/cmd/mode.go +++ b/src/go/rpk/pkg/cli/cmd/mode.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda.go b/src/go/rpk/pkg/cli/cmd/redpanda.go index 18cd51794e24..5b9a37b6c7af 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/admin/admin.go b/src/go/rpk/pkg/cli/cmd/redpanda/admin/admin.go index b504fd181bc4..1d1cde4cd235 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/admin/admin.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/admin/admin.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/admin/brokers/brokers.go b/src/go/rpk/pkg/cli/cmd/redpanda/admin/brokers/brokers.go index 936c38e17893..6deec0a37ba3 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/admin/brokers/brokers.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/admin/brokers/brokers.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/check.go b/src/go/rpk/pkg/cli/cmd/redpanda/check.go index 3ed0eda8f30d..62964926be77 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/check.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/check.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/config.go b/src/go/rpk/pkg/cli/cmd/redpanda/config.go index 4818c12b824b..ef844dd7054d 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/config.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/config_test.go b/src/go/rpk/pkg/cli/cmd/redpanda/config_test.go index 0e9c5bfe06f5..b74cbba65aa8 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/config_test.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/config_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/mode.go b/src/go/rpk/pkg/cli/cmd/redpanda/mode.go index 4ab3f212c541..0378d76fd86f 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/mode.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/mode.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/mode_test.go b/src/go/rpk/pkg/cli/cmd/redpanda/mode_test.go index 619b2c0aebab..e62ce2093a06 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/mode_test.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/mode_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/package.go b/src/go/rpk/pkg/cli/cmd/redpanda/package.go index 941df113219d..b8351865a57c 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/package.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/package.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/start.go b/src/go/rpk/pkg/cli/cmd/redpanda/start.go index 10b46d4d24af..d3c2890ff1f7 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/start.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/start.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/start_test.go b/src/go/rpk/pkg/cli/cmd/redpanda/start_test.go index 735ca84d4315..ecc159faa56a 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/start_test.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/start_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/stop.go b/src/go/rpk/pkg/cli/cmd/redpanda/stop.go index 950b75bb99d1..1685ddbad458 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/stop.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/stop.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/stop_test.go b/src/go/rpk/pkg/cli/cmd/redpanda/stop_test.go index f62259765f7c..f6e4319ba4f3 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/stop_test.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/stop_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/tune.go b/src/go/rpk/pkg/cli/cmd/redpanda/tune.go index 057b4bb8f786..169eca2f6fec 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/tune.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/tune.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/tune/help.go b/src/go/rpk/pkg/cli/cmd/redpanda/tune/help.go index 51372fdf7007..8666061601ab 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/tune/help.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/tune/help.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/redpanda/tune_test.go b/src/go/rpk/pkg/cli/cmd/redpanda/tune_test.go index 2efdf8c7bfda..df8d9f0a093f 100644 --- a/src/go/rpk/pkg/cli/cmd/redpanda/tune_test.go +++ b/src/go/rpk/pkg/cli/cmd/redpanda/tune_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/start.go b/src/go/rpk/pkg/cli/cmd/start.go index 7a327d9ff572..db83e7f97b6d 100644 --- a/src/go/rpk/pkg/cli/cmd/start.go +++ b/src/go/rpk/pkg/cli/cmd/start.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/stop.go b/src/go/rpk/pkg/cli/cmd/stop.go index da292e369188..86adf9d278e0 100644 --- a/src/go/rpk/pkg/cli/cmd/stop.go +++ b/src/go/rpk/pkg/cli/cmd/stop.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic.go b/src/go/rpk/pkg/cli/cmd/topic.go index d28111e87a60..fb1556e6b094 100644 --- a/src/go/rpk/pkg/cli/cmd/topic.go +++ b/src/go/rpk/pkg/cli/cmd/topic.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/add_partitions.go b/src/go/rpk/pkg/cli/cmd/topic/add_partitions.go index c9bfc444cdfc..91d8fae6773a 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/add_partitions.go +++ b/src/go/rpk/pkg/cli/cmd/topic/add_partitions.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/config.go b/src/go/rpk/pkg/cli/cmd/topic/config.go index 4faa33e70084..61faae7ff468 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/config.go +++ b/src/go/rpk/pkg/cli/cmd/topic/config.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/consume.go b/src/go/rpk/pkg/cli/cmd/topic/consume.go index 2a574ef1eddb..28cf11f9abbb 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/consume.go +++ b/src/go/rpk/pkg/cli/cmd/topic/consume.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/create.go b/src/go/rpk/pkg/cli/cmd/topic/create.go index babaa1751c1c..67e1890cd2f4 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/create.go +++ b/src/go/rpk/pkg/cli/cmd/topic/create.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/delete.go b/src/go/rpk/pkg/cli/cmd/topic/delete.go index 295224de59dd..56290062694f 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/delete.go +++ b/src/go/rpk/pkg/cli/cmd/topic/delete.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/describe.go b/src/go/rpk/pkg/cli/cmd/topic/describe.go index f916694ee0f4..484bf7ce4023 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/describe.go +++ b/src/go/rpk/pkg/cli/cmd/topic/describe.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/list.go b/src/go/rpk/pkg/cli/cmd/topic/list.go index 98362b23210a..166093b62b82 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/list.go +++ b/src/go/rpk/pkg/cli/cmd/topic/list.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/produce.go b/src/go/rpk/pkg/cli/cmd/topic/produce.go index 89538f287ee0..1c6b1bd30c5a 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/produce.go +++ b/src/go/rpk/pkg/cli/cmd/topic/produce.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/utils.go b/src/go/rpk/pkg/cli/cmd/topic/utils.go index bb19a52a3d92..005dc3adab44 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/utils.go +++ b/src/go/rpk/pkg/cli/cmd/topic/utils.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/topic/utils_test.go b/src/go/rpk/pkg/cli/cmd/topic/utils_test.go index d6f2a8e3efbf..2f2fa7e1f809 100644 --- a/src/go/rpk/pkg/cli/cmd/topic/utils_test.go +++ b/src/go/rpk/pkg/cli/cmd/topic/utils_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/tune.go b/src/go/rpk/pkg/cli/cmd/tune.go index 1cf18722f9d2..2373211fa794 100644 --- a/src/go/rpk/pkg/cli/cmd/tune.go +++ b/src/go/rpk/pkg/cli/cmd/tune.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/metrics.go b/src/go/rpk/pkg/system/metrics.go index 92567b116572..c79baaa8b40c 100644 --- a/src/go/rpk/pkg/system/metrics.go +++ b/src/go/rpk/pkg/system/metrics.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/metrics_test.go b/src/go/rpk/pkg/system/metrics_test.go index 55e404433c89..59a1cd73f852 100644 --- a/src/go/rpk/pkg/system/metrics_test.go +++ b/src/go/rpk/pkg/system/metrics_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/syslog/package.go b/src/go/rpk/pkg/system/syslog/package.go index 1b929df5ec48..bd3ae6368de8 100644 --- a/src/go/rpk/pkg/system/syslog/package.go +++ b/src/go/rpk/pkg/system/syslog/package.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/system/syslog/syslog.go b/src/go/rpk/pkg/system/syslog/syslog.go index a081cb124ff7..e656ffe77d4d 100644 --- a/src/go/rpk/pkg/system/syslog/syslog.go +++ b/src/go/rpk/pkg/system/syslog/syslog.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/ballast/tuner.go b/src/go/rpk/pkg/tuners/ballast/tuner.go index 38717d73c87d..86f705c7184d 100644 --- a/src/go/rpk/pkg/tuners/ballast/tuner.go +++ b/src/go/rpk/pkg/tuners/ballast/tuner.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/commands/write_sized_file.go b/src/go/rpk/pkg/tuners/executors/commands/write_sized_file.go index 5f7b8fc81ed5..e5d16603e3f3 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_sized_file.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_sized_file.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/executors/commands/write_sized_file_test.go b/src/go/rpk/pkg/tuners/executors/commands/write_sized_file_test.go index d28359c03f4a..749ff046eb60 100644 --- a/src/go/rpk/pkg/tuners/executors/commands/write_sized_file_test.go +++ b/src/go/rpk/pkg/tuners/executors/commands/write_sized_file_test.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/tuners/factory/factory.go b/src/go/rpk/pkg/tuners/factory/factory.go index b11dc15eb776..1565aaae35bc 100644 --- a/src/go/rpk/pkg/tuners/factory/factory.go +++ b/src/go/rpk/pkg/tuners/factory/factory.go @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/archival/archival_policy.cc b/src/v/archival/archival_policy.cc index be43875c1748..f73ff864ca46 100644 --- a/src/v/archival/archival_policy.cc +++ b/src/v/archival/archival_policy.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/archival_policy.h b/src/v/archival/archival_policy.h index 94975eb7116a..1e585e2e495f 100644 --- a/src/v/archival/archival_policy.h +++ b/src/v/archival/archival_policy.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/fwd.h b/src/v/archival/fwd.h index cf97cabc6cc4..da4f45b66bf3 100644 --- a/src/v/archival/fwd.h +++ b/src/v/archival/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/logger.h b/src/v/archival/logger.h index b0161ef90a9f..6cb14016e069 100644 --- a/src/v/archival/logger.h +++ b/src/v/archival/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/ntp_archiver_service.cc b/src/v/archival/ntp_archiver_service.cc index 05aef62d9464..eb88aeec7416 100644 --- a/src/v/archival/ntp_archiver_service.cc +++ b/src/v/archival/ntp_archiver_service.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/ntp_archiver_service.h b/src/v/archival/ntp_archiver_service.h index a21f39685772..d8841d59e715 100644 --- a/src/v/archival/ntp_archiver_service.h +++ b/src/v/archival/ntp_archiver_service.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/probe.cc b/src/v/archival/probe.cc index d928b433d9a5..f5008f8e9069 100644 --- a/src/v/archival/probe.cc +++ b/src/v/archival/probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/probe.h b/src/v/archival/probe.h index 59ad13ab598f..13b19a6d35a8 100644 --- a/src/v/archival/probe.h +++ b/src/v/archival/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/service.cc b/src/v/archival/service.cc index 870a1cb12416..e975c8da84a9 100644 --- a/src/v/archival/service.cc +++ b/src/v/archival/service.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/service.h b/src/v/archival/service.h index 163b605f4899..981acd0e798f 100644 --- a/src/v/archival/service.h +++ b/src/v/archival/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/tests/ntp_archiver_test.cc b/src/v/archival/tests/ntp_archiver_test.cc index 3add3a5a52b8..a6643d48b473 100644 --- a/src/v/archival/tests/ntp_archiver_test.cc +++ b/src/v/archival/tests/ntp_archiver_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/tests/service_fixture.cc b/src/v/archival/tests/service_fixture.cc index fe3d19f5c0a9..2c4f65dd762a 100644 --- a/src/v/archival/tests/service_fixture.cc +++ b/src/v/archival/tests/service_fixture.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/tests/service_fixture.h b/src/v/archival/tests/service_fixture.h index 5c3cb9bdd433..7449ffe610d2 100644 --- a/src/v/archival/tests/service_fixture.h +++ b/src/v/archival/tests/service_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/tests/service_test.cc b/src/v/archival/tests/service_test.cc index 50a3734e0353..c476bc5de848 100644 --- a/src/v/archival/tests/service_test.cc +++ b/src/v/archival/tests/service_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/types.cc b/src/v/archival/types.cc index 215e5068fced..a358fe78de62 100644 --- a/src/v/archival/types.cc +++ b/src/v/archival/types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/types.h b/src/v/archival/types.h index fdfc708a62ed..8201fcb766f5 100644 --- a/src/v/archival/types.h +++ b/src/v/archival/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/upload_controller.cc b/src/v/archival/upload_controller.cc index 52f1b2d9f683..4498fc53d175 100644 --- a/src/v/archival/upload_controller.cc +++ b/src/v/archival/upload_controller.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/archival/upload_controller.h b/src/v/archival/upload_controller.h index 5217b0a5338a..4f81293b5207 100644 --- a/src/v/archival/upload_controller.h +++ b/src/v/archival/upload_controller.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/cache_service.cc b/src/v/cloud_storage/cache_service.cc index 535d5237d7b1..ec2e639fb244 100644 --- a/src/v/cloud_storage/cache_service.cc +++ b/src/v/cloud_storage/cache_service.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/cache_service.h b/src/v/cloud_storage/cache_service.h index 335b368bf5e4..f45ecf24bffc 100644 --- a/src/v/cloud_storage/cache_service.h +++ b/src/v/cloud_storage/cache_service.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/fwd.h b/src/v/cloud_storage/fwd.h index 9e497bd912e0..6256c4aac751 100644 --- a/src/v/cloud_storage/fwd.h +++ b/src/v/cloud_storage/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/logger.h b/src/v/cloud_storage/logger.h index f1cd60b3ee97..290fbbe12cea 100644 --- a/src/v/cloud_storage/logger.h +++ b/src/v/cloud_storage/logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/offset_translation_layer.cc b/src/v/cloud_storage/offset_translation_layer.cc index b3dbce760996..eb55d6fce2f6 100644 --- a/src/v/cloud_storage/offset_translation_layer.cc +++ b/src/v/cloud_storage/offset_translation_layer.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/offset_translation_layer.h b/src/v/cloud_storage/offset_translation_layer.h index 003fc79b28ae..246ad848e24f 100644 --- a/src/v/cloud_storage/offset_translation_layer.h +++ b/src/v/cloud_storage/offset_translation_layer.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/probe.cc b/src/v/cloud_storage/probe.cc index 150e2ba67e7b..2bad69612b22 100644 --- a/src/v/cloud_storage/probe.cc +++ b/src/v/cloud_storage/probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/probe.h b/src/v/cloud_storage/probe.h index ef7d54d3e6b1..6a92390cb550 100644 --- a/src/v/cloud_storage/probe.h +++ b/src/v/cloud_storage/probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote.cc b/src/v/cloud_storage/remote.cc index 86797bdf86f9..3264db55c549 100644 --- a/src/v/cloud_storage/remote.cc +++ b/src/v/cloud_storage/remote.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote.h b/src/v/cloud_storage/remote.h index ff49e7c89890..d257895b8bed 100644 --- a/src/v/cloud_storage/remote.h +++ b/src/v/cloud_storage/remote.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_partition.cc b/src/v/cloud_storage/remote_partition.cc index 23c5144d6dd4..1b5c522b52d4 100644 --- a/src/v/cloud_storage/remote_partition.cc +++ b/src/v/cloud_storage/remote_partition.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_partition.h b/src/v/cloud_storage/remote_partition.h index 2182dae677bf..d4ace5a51176 100644 --- a/src/v/cloud_storage/remote_partition.h +++ b/src/v/cloud_storage/remote_partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/cache_test.cc b/src/v/cloud_storage/tests/cache_test.cc index f4c296357558..1920b9a56b37 100644 --- a/src/v/cloud_storage/tests/cache_test.cc +++ b/src/v/cloud_storage/tests/cache_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/cache_test_fixture.h b/src/v/cloud_storage/tests/cache_test_fixture.h index 763624cbc676..4d24964d4864 100644 --- a/src/v/cloud_storage/tests/cache_test_fixture.h +++ b/src/v/cloud_storage/tests/cache_test_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/cloud_storage_fixture.h b/src/v/cloud_storage/tests/cloud_storage_fixture.h index ee9cc0050fa8..1432dbf27bc3 100644 --- a/src/v/cloud_storage/tests/cloud_storage_fixture.h +++ b/src/v/cloud_storage/tests/cloud_storage_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/directory_walker_test.cc b/src/v/cloud_storage/tests/directory_walker_test.cc index 0a490fbbde75..3b3647543655 100644 --- a/src/v/cloud_storage/tests/directory_walker_test.cc +++ b/src/v/cloud_storage/tests/directory_walker_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/offset_translation_layer_test.cc b/src/v/cloud_storage/tests/offset_translation_layer_test.cc index 9507876263ce..d818ac4571f5 100644 --- a/src/v/cloud_storage/tests/offset_translation_layer_test.cc +++ b/src/v/cloud_storage/tests/offset_translation_layer_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/remote_partition_test.cc b/src/v/cloud_storage/tests/remote_partition_test.cc index c6f2cca14730..cc516956bc91 100644 --- a/src/v/cloud_storage/tests/remote_partition_test.cc +++ b/src/v/cloud_storage/tests/remote_partition_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/remote_segment_test.cc b/src/v/cloud_storage/tests/remote_segment_test.cc index 0f6bc5e31343..a34d3ffefa51 100644 --- a/src/v/cloud_storage/tests/remote_segment_test.cc +++ b/src/v/cloud_storage/tests/remote_segment_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/remote_test.cc b/src/v/cloud_storage/tests/remote_test.cc index 1b904f25f667..a1347e3fffa2 100644 --- a/src/v/cloud_storage/tests/remote_test.cc +++ b/src/v/cloud_storage/tests/remote_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/s3_imposter.cc b/src/v/cloud_storage/tests/s3_imposter.cc index 11a6885191a1..df30c4b83da7 100644 --- a/src/v/cloud_storage/tests/s3_imposter.cc +++ b/src/v/cloud_storage/tests/s3_imposter.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/s3_imposter.h b/src/v/cloud_storage/tests/s3_imposter.h index 82c88efb01a2..be332b401fc6 100644 --- a/src/v/cloud_storage/tests/s3_imposter.h +++ b/src/v/cloud_storage/tests/s3_imposter.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/topic_manifest_test.cc b/src/v/cloud_storage/tests/topic_manifest_test.cc index 2c4cb7c427a2..b76c79658b72 100644 --- a/src/v/cloud_storage/tests/topic_manifest_test.cc +++ b/src/v/cloud_storage/tests/topic_manifest_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cluster/archival_metadata_stm.cc b/src/v/cluster/archival_metadata_stm.cc index 52d300d677b2..2ae4aa005716 100644 --- a/src/v/cluster/archival_metadata_stm.cc +++ b/src/v/cluster/archival_metadata_stm.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cluster/archival_metadata_stm.h b/src/v/cluster/archival_metadata_stm.h index a60c94639d6f..e376d014a406 100644 --- a/src/v/cluster/archival_metadata_stm.h +++ b/src/v/cluster/archival_metadata_stm.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/config_frontend.cc b/src/v/cluster/config_frontend.cc index 3fa2fe96cd17..3524f80d5e6d 100644 --- a/src/v/cluster/config_frontend.cc +++ b/src/v/cluster/config_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/config_frontend.h b/src/v/cluster/config_frontend.h index 645980befdb6..e1a27e655366 100644 --- a/src/v/cluster/config_frontend.h +++ b/src/v/cluster/config_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/config_manager.cc b/src/v/cluster/config_manager.cc index 355d93f15066..86bb39512cf7 100644 --- a/src/v/cluster/config_manager.cc +++ b/src/v/cluster/config_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/config_manager.h b/src/v/cluster/config_manager.h index 5146359c997e..bd029d56d7b0 100644 --- a/src/v/cluster/config_manager.h +++ b/src/v/cluster/config_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/data_policy_frontend.cc b/src/v/cluster/data_policy_frontend.cc index e10e3b2d1e0f..bf27cf0a6bb0 100644 --- a/src/v/cluster/data_policy_frontend.cc +++ b/src/v/cluster/data_policy_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/data_policy_frontend.h b/src/v/cluster/data_policy_frontend.h index ae31e6c09d9f..ce453ec47a38 100644 --- a/src/v/cluster/data_policy_frontend.h +++ b/src/v/cluster/data_policy_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/data_policy_manager.cc b/src/v/cluster/data_policy_manager.cc index 6005c09ff1d4..92e14b0b60a5 100644 --- a/src/v/cluster/data_policy_manager.cc +++ b/src/v/cluster/data_policy_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/data_policy_manager.h b/src/v/cluster/data_policy_manager.h index 8f6b71b267be..354c3bd28559 100644 --- a/src/v/cluster/data_policy_manager.h +++ b/src/v/cluster/data_policy_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_manager.h b/src/v/cluster/feature_manager.h index 451e825e61b6..d9bb5bc1e019 100644 --- a/src/v/cluster/feature_manager.h +++ b/src/v/cluster/feature_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_table.cc b/src/v/cluster/feature_table.cc index 705bad986333..140125e00f42 100644 --- a/src/v/cluster/feature_table.cc +++ b/src/v/cluster/feature_table.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_manager.cc b/src/v/cluster/health_manager.cc index 1ef9474beb2c..885674443319 100644 --- a/src/v/cluster/health_manager.cc +++ b/src/v/cluster/health_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/health_manager.h b/src/v/cluster/health_manager.h index 138bca6dd46b..b66a0f6eb582 100644 --- a/src/v/cluster/health_manager.h +++ b/src/v/cluster/health_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/metrics_reporter.cc b/src/v/cluster/metrics_reporter.cc index ed47cdeffc36..d2bc043cd41c 100644 --- a/src/v/cluster/metrics_reporter.cc +++ b/src/v/cluster/metrics_reporter.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/node/local_monitor.cc b/src/v/cluster/node/local_monitor.cc index ab7518075c6f..9a34f90ec01f 100644 --- a/src/v/cluster/node/local_monitor.cc +++ b/src/v/cluster/node/local_monitor.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/node/local_monitor.h b/src/v/cluster/node/local_monitor.h index 0a1ba4dc33e0..52abac82aa71 100644 --- a/src/v/cluster/node/local_monitor.h +++ b/src/v/cluster/node/local_monitor.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/node/types.cc b/src/v/cluster/node/types.cc index 95874147c262..7db1e52ebdbd 100644 --- a/src/v/cluster/node/types.cc +++ b/src/v/cluster/node/types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/node/types.h b/src/v/cluster/node/types.h index 613e03d8ab88..9402c24c0a60 100644 --- a/src/v/cluster/node/types.h +++ b/src/v/cluster/node/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/non_replicable_topics_frontend.cc b/src/v/cluster/non_replicable_topics_frontend.cc index 289337be0964..508ee4c300c2 100644 --- a/src/v/cluster/non_replicable_topics_frontend.cc +++ b/src/v/cluster/non_replicable_topics_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/non_replicable_topics_frontend.h b/src/v/cluster/non_replicable_topics_frontend.h index 8395f506181d..e39deb5a4664 100644 --- a/src/v/cluster/non_replicable_topics_frontend.h +++ b/src/v/cluster/non_replicable_topics_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/scheduling/leader_balancer_greedy.h b/src/v/cluster/scheduling/leader_balancer_greedy.h index d0f9b4205309..1a5f330fe9dc 100644 --- a/src/v/cluster/scheduling/leader_balancer_greedy.h +++ b/src/v/cluster/scheduling/leader_balancer_greedy.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/security_manager.h b/src/v/cluster/security_manager.h index 2006be412565..3b0933f92d76 100644 --- a/src/v/cluster/security_manager.h +++ b/src/v/cluster/security_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/data_policy_controller_test.cc b/src/v/cluster/tests/data_policy_controller_test.cc index a5047146cd7b..339accc0f7c1 100644 --- a/src/v/cluster/tests/data_policy_controller_test.cc +++ b/src/v/cluster/tests/data_policy_controller_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/leader_balancer_test.cc b/src/v/cluster/tests/leader_balancer_test.cc index 71bc5987d419..19a54e8cfa16 100644 --- a/src/v/cluster/tests/leader_balancer_test.cc +++ b/src/v/cluster/tests/leader_balancer_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/metrics_reporter_test.cc b/src/v/cluster/tests/metrics_reporter_test.cc index 1afae6882be2..28ec71e3c80a 100644 --- a/src/v/cluster/tests/metrics_reporter_test.cc +++ b/src/v/cluster/tests/metrics_reporter_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/topic_configuration_compat_test.cc b/src/v/cluster/tests/topic_configuration_compat_test.cc index 730525f048e8..f8d2e9200cb5 100644 --- a/src/v/cluster/tests/topic_configuration_compat_test.cc +++ b/src/v/cluster/tests/topic_configuration_compat_test.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/broker_endpoint.h b/src/v/config/broker_endpoint.h index c761b2f50de6..3de0f2dfabd9 100644 --- a/src/v/config/broker_endpoint.h +++ b/src/v/config/broker_endpoint.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/convert.h b/src/v/config/convert.h index 1792abb1e2d3..f116ddf307a1 100644 --- a/src/v/config/convert.h +++ b/src/v/config/convert.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/node_config.cc b/src/v/config/node_config.cc index 74657620000d..8ad59eb9fe44 100644 --- a/src/v/config/node_config.cc +++ b/src/v/config/node_config.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/node_config.h b/src/v/config/node_config.h index 53c4b1a3c22c..6e50f0fefc8e 100644 --- a/src/v/config/node_config.h +++ b/src/v/config/node_config.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/coproc/api.cc b/src/v/coproc/api.cc index cbdd818e5c4c..5bc13aa18d09 100644 --- a/src/v/coproc/api.cc +++ b/src/v/coproc/api.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/event_handler.cc b/src/v/coproc/event_handler.cc index 7d5f1db60e93..e6b920c6f3d2 100644 --- a/src/v/coproc/event_handler.cc +++ b/src/v/coproc/event_handler.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/event_handler.h b/src/v/coproc/event_handler.h index 51826dd2b312..46af4aaf446b 100644 --- a/src/v/coproc/event_handler.h +++ b/src/v/coproc/event_handler.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/exception.h b/src/v/coproc/exception.h index 10e11622dea9..90b7c16bee69 100644 --- a/src/v/coproc/exception.h +++ b/src/v/coproc/exception.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/fwd.h b/src/v/coproc/fwd.h index fe9804f178aa..dcfc85c863ba 100644 --- a/src/v/coproc/fwd.h +++ b/src/v/coproc/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/partition.cc b/src/v/coproc/partition.cc index f9a92d95171d..17198fb7c500 100644 --- a/src/v/coproc/partition.cc +++ b/src/v/coproc/partition.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/partition.h b/src/v/coproc/partition.h index 717e9636a4ea..be2d714d84bd 100644 --- a/src/v/coproc/partition.h +++ b/src/v/coproc/partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/partition_manager.cc b/src/v/coproc/partition_manager.cc index 10937c69c4cf..1b067b9b2552 100644 --- a/src/v/coproc/partition_manager.cc +++ b/src/v/coproc/partition_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/partition_manager.h b/src/v/coproc/partition_manager.h index f5b3103ec1bd..6f46417e022e 100644 --- a/src/v/coproc/partition_manager.h +++ b/src/v/coproc/partition_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/reconciliation_backend.cc b/src/v/coproc/reconciliation_backend.cc index 9dea7d3a2d12..537b84acdbe7 100644 --- a/src/v/coproc/reconciliation_backend.cc +++ b/src/v/coproc/reconciliation_backend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/reconciliation_backend.h b/src/v/coproc/reconciliation_backend.h index 1c520bb1c462..0e8408be364c 100644 --- a/src/v/coproc/reconciliation_backend.h +++ b/src/v/coproc/reconciliation_backend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/reference_window_consumer.hpp b/src/v/coproc/reference_window_consumer.hpp index 3ea3a8e2808a..0870e34d5839 100644 --- a/src/v/coproc/reference_window_consumer.hpp +++ b/src/v/coproc/reference_window_consumer.hpp @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_backend.cc b/src/v/coproc/script_context_backend.cc index 7d763b4b50c5..0a31a87e4ef3 100644 --- a/src/v/coproc/script_context_backend.cc +++ b/src/v/coproc/script_context_backend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_backend.h b/src/v/coproc/script_context_backend.h index 1a77a09a6257..968fd02a7ab2 100644 --- a/src/v/coproc/script_context_backend.h +++ b/src/v/coproc/script_context_backend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_frontend.cc b/src/v/coproc/script_context_frontend.cc index 97a6733eb4d9..0eb064a787db 100644 --- a/src/v/coproc/script_context_frontend.cc +++ b/src/v/coproc/script_context_frontend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_frontend.h b/src/v/coproc/script_context_frontend.h index d1da687d3c14..2a2ee11caac8 100644 --- a/src/v/coproc/script_context_frontend.h +++ b/src/v/coproc/script_context_frontend.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_router.cc b/src/v/coproc/script_context_router.cc index 4860b30a4975..bf95c9a3f09f 100644 --- a/src/v/coproc/script_context_router.cc +++ b/src/v/coproc/script_context_router.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_context_router.h b/src/v/coproc/script_context_router.h index 6499486e9018..2eabc18bcb03 100644 --- a/src/v/coproc/script_context_router.h +++ b/src/v/coproc/script_context_router.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/script_database.h b/src/v/coproc/script_database.h index 40f1093febf4..8c8a6cbbe5f4 100644 --- a/src/v/coproc/script_database.h +++ b/src/v/coproc/script_database.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/sys_refs.h b/src/v/coproc/sys_refs.h index 57bb6b2cb5d6..de89f0a556f6 100644 --- a/src/v/coproc/sys_refs.h +++ b/src/v/coproc/sys_refs.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/event_handler_tests.cc b/src/v/coproc/tests/event_handler_tests.cc index 0c08b5596190..cb74ffe796da 100644 --- a/src/v/coproc/tests/event_handler_tests.cc +++ b/src/v/coproc/tests/event_handler_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/fixtures/coproc_cluster_fixture.cc b/src/v/coproc/tests/fixtures/coproc_cluster_fixture.cc index e2e5cf2c8af3..951258522141 100644 --- a/src/v/coproc/tests/fixtures/coproc_cluster_fixture.cc +++ b/src/v/coproc/tests/fixtures/coproc_cluster_fixture.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/coproc_cluster_fixture.h b/src/v/coproc/tests/fixtures/coproc_cluster_fixture.h index d8f556b0153d..973672cd2028 100644 --- a/src/v/coproc/tests/fixtures/coproc_cluster_fixture.h +++ b/src/v/coproc/tests/fixtures/coproc_cluster_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/fiber_mock_fixture.cc b/src/v/coproc/tests/fixtures/fiber_mock_fixture.cc index b56c781b66cd..06e8e9513efc 100644 --- a/src/v/coproc/tests/fixtures/fiber_mock_fixture.cc +++ b/src/v/coproc/tests/fixtures/fiber_mock_fixture.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/fixtures/fiber_mock_fixture.h b/src/v/coproc/tests/fixtures/fiber_mock_fixture.h index f0fc29191f41..8c441d9f66e1 100644 --- a/src/v/coproc/tests/fixtures/fiber_mock_fixture.h +++ b/src/v/coproc/tests/fixtures/fiber_mock_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/partition_movement_tests.cc b/src/v/coproc/tests/partition_movement_tests.cc index b7fa187123a7..0e0a880cdc4d 100644 --- a/src/v/coproc/tests/partition_movement_tests.cc +++ b/src/v/coproc/tests/partition_movement_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/topic_ingestion_policy_tests.cc b/src/v/coproc/tests/topic_ingestion_policy_tests.cc index 0633aa20dc1e..28a2304abfde 100644 --- a/src/v/coproc/tests/topic_ingestion_policy_tests.cc +++ b/src/v/coproc/tests/topic_ingestion_policy_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/coproc/tests/utils/batch_utils.cc b/src/v/coproc/tests/utils/batch_utils.cc index b01b14caa425..279288e399b8 100644 --- a/src/v/coproc/tests/utils/batch_utils.cc +++ b/src/v/coproc/tests/utils/batch_utils.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/utils/batch_utils.h b/src/v/coproc/tests/utils/batch_utils.h index 3ddb427a73ab..7aafa84bc7a3 100644 --- a/src/v/coproc/tests/utils/batch_utils.h +++ b/src/v/coproc/tests/utils/batch_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/utils/kafka_publish_consumer.h b/src/v/coproc/tests/utils/kafka_publish_consumer.h index 23c91cffd88b..59719b14b5eb 100644 --- a/src/v/coproc/tests/utils/kafka_publish_consumer.h +++ b/src/v/coproc/tests/utils/kafka_publish_consumer.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/hashing/crc32.h b/src/v/hashing/crc32.h index 411bfb63e689..18a8f85952f6 100644 --- a/src/v/hashing/crc32.h +++ b/src/v/hashing/crc32.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/client_fetch_batch_reader.cc b/src/v/kafka/client/client_fetch_batch_reader.cc index 15cdcf24ad64..7bbe6efb0cf4 100644 --- a/src/v/kafka/client/client_fetch_batch_reader.cc +++ b/src/v/kafka/client/client_fetch_batch_reader.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/client_fetch_batch_reader.h b/src/v/kafka/client/client_fetch_batch_reader.h index aa58123cc822..089821398519 100644 --- a/src/v/kafka/client/client_fetch_batch_reader.h +++ b/src/v/kafka/client/client_fetch_batch_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/fetch_session.h b/src/v/kafka/client/fetch_session.h index 3dccb59b29cf..0112af24d16d 100644 --- a/src/v/kafka/client/fetch_session.h +++ b/src/v/kafka/client/fetch_session.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/fwd.h b/src/v/kafka/client/fwd.h index ae9fd9a7e4b0..ba1d8585299f 100644 --- a/src/v/kafka/client/fwd.h +++ b/src/v/kafka/client/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/partitioners.cc b/src/v/kafka/client/partitioners.cc index 3398204f57dd..b2b92803cac5 100644 --- a/src/v/kafka/client/partitioners.cc +++ b/src/v/kafka/client/partitioners.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/partitioners.h b/src/v/kafka/client/partitioners.h index af9f9b4b6791..2ecb9aea8e12 100644 --- a/src/v/kafka/client/partitioners.h +++ b/src/v/kafka/client/partitioners.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/sasl_client.cc b/src/v/kafka/client/sasl_client.cc index 3c037e9cd6fd..db4e17b48ec4 100644 --- a/src/v/kafka/client/sasl_client.cc +++ b/src/v/kafka/client/sasl_client.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/sasl_client.h b/src/v/kafka/client/sasl_client.h index fcde29faee68..2f565dae91f2 100644 --- a/src/v/kafka/client/sasl_client.h +++ b/src/v/kafka/client/sasl_client.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/client/test/retry.cc b/src/v/kafka/client/test/retry.cc index f57e5338de7b..ae87a2919fa4 100644 --- a/src/v/kafka/client/test/retry.cc +++ b/src/v/kafka/client/test/retry.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/kafka/client/types.h b/src/v/kafka/client/types.h index 0527440760ee..df2e915fd01d 100644 --- a/src/v/kafka/client/types.h +++ b/src/v/kafka/client/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/group_probe.h b/src/v/kafka/group_probe.h index 8b26f2b42343..1b51d515e845 100644 --- a/src/v/kafka/group_probe.h +++ b/src/v/kafka/group_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/latency_probe.h b/src/v/kafka/latency_probe.h index cb6e15cdd467..ef161c134ce7 100644 --- a/src/v/kafka/latency_probe.h +++ b/src/v/kafka/latency_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/protocol/legacy_message.h b/src/v/kafka/protocol/legacy_message.h index 5443220290fe..01ab290ba209 100644 --- a/src/v/kafka/protocol/legacy_message.h +++ b/src/v/kafka/protocol/legacy_message.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/errors.h b/src/v/kafka/server/errors.h index 106cadb8aad5..40473d075b29 100644 --- a/src/v/kafka/server/errors.h +++ b/src/v/kafka/server/errors.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/add_offsets_to_txn.h b/src/v/kafka/server/handlers/add_offsets_to_txn.h index 2555b7acf90f..e4b1669b970a 100644 --- a/src/v/kafka/server/handlers/add_offsets_to_txn.h +++ b/src/v/kafka/server/handlers/add_offsets_to_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/add_partitions_to_txn.h b/src/v/kafka/server/handlers/add_partitions_to_txn.h index ff8b514e58e0..5b0f2523b4f3 100644 --- a/src/v/kafka/server/handlers/add_partitions_to_txn.h +++ b/src/v/kafka/server/handlers/add_partitions_to_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/alter_configs.h b/src/v/kafka/server/handlers/alter_configs.h index 8c46bfe1065c..7edcf2f987ad 100644 --- a/src/v/kafka/server/handlers/alter_configs.h +++ b/src/v/kafka/server/handlers/alter_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/api_versions.h b/src/v/kafka/server/handlers/api_versions.h index a075f1d5175a..def3a6e2a4d4 100644 --- a/src/v/kafka/server/handlers/api_versions.h +++ b/src/v/kafka/server/handlers/api_versions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/configs/config_utils.h b/src/v/kafka/server/handlers/configs/config_utils.h index 021bd169cc23..cd0572263446 100644 --- a/src/v/kafka/server/handlers/configs/config_utils.h +++ b/src/v/kafka/server/handlers/configs/config_utils.h @@ -1,6 +1,6 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_acls.cc b/src/v/kafka/server/handlers/create_acls.cc index 2c43ddd1ff3f..97c1d8a6978b 100644 --- a/src/v/kafka/server/handlers/create_acls.cc +++ b/src/v/kafka/server/handlers/create_acls.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_acls.h b/src/v/kafka/server/handlers/create_acls.h index c89f975ddd37..e9719121d6df 100644 --- a/src/v/kafka/server/handlers/create_acls.h +++ b/src/v/kafka/server/handlers/create_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_partitions.h b/src/v/kafka/server/handlers/create_partitions.h index 40411587ae9d..4102398e8d8b 100644 --- a/src/v/kafka/server/handlers/create_partitions.h +++ b/src/v/kafka/server/handlers/create_partitions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/create_topics.h b/src/v/kafka/server/handlers/create_topics.h index 65f8ce610d9a..2f2774856173 100644 --- a/src/v/kafka/server/handlers/create_topics.h +++ b/src/v/kafka/server/handlers/create_topics.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_acls.cc b/src/v/kafka/server/handlers/delete_acls.cc index bd28f16cfbe2..276bfcd4db87 100644 --- a/src/v/kafka/server/handlers/delete_acls.cc +++ b/src/v/kafka/server/handlers/delete_acls.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_acls.h b/src/v/kafka/server/handlers/delete_acls.h index 814d847dfa37..d19ab798cf46 100644 --- a/src/v/kafka/server/handlers/delete_acls.h +++ b/src/v/kafka/server/handlers/delete_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_groups.h b/src/v/kafka/server/handlers/delete_groups.h index 6f376ec13978..85d01eb8c29b 100644 --- a/src/v/kafka/server/handlers/delete_groups.h +++ b/src/v/kafka/server/handlers/delete_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/delete_topics.h b/src/v/kafka/server/handlers/delete_topics.h index 0dad169e8802..7dd8d66d2f15 100644 --- a/src/v/kafka/server/handlers/delete_topics.h +++ b/src/v/kafka/server/handlers/delete_topics.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_acls.cc b/src/v/kafka/server/handlers/describe_acls.cc index dc69a91a0525..eea31f0a834e 100644 --- a/src/v/kafka/server/handlers/describe_acls.cc +++ b/src/v/kafka/server/handlers/describe_acls.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_acls.h b/src/v/kafka/server/handlers/describe_acls.h index 475c83e7aeb7..3377ac8a2858 100644 --- a/src/v/kafka/server/handlers/describe_acls.h +++ b/src/v/kafka/server/handlers/describe_acls.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_configs.h b/src/v/kafka/server/handlers/describe_configs.h index a25ef02508ee..27f7235dc762 100644 --- a/src/v/kafka/server/handlers/describe_configs.h +++ b/src/v/kafka/server/handlers/describe_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_groups.h b/src/v/kafka/server/handlers/describe_groups.h index b7e9b353988a..f93110d323c5 100644 --- a/src/v/kafka/server/handlers/describe_groups.h +++ b/src/v/kafka/server/handlers/describe_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_log_dirs.cc b/src/v/kafka/server/handlers/describe_log_dirs.cc index c0500bf24bc0..514b7808da7e 100644 --- a/src/v/kafka/server/handlers/describe_log_dirs.cc +++ b/src/v/kafka/server/handlers/describe_log_dirs.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/describe_log_dirs.h b/src/v/kafka/server/handlers/describe_log_dirs.h index 58d1b6ba4a2a..13d11c440ad7 100644 --- a/src/v/kafka/server/handlers/describe_log_dirs.h +++ b/src/v/kafka/server/handlers/describe_log_dirs.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/details/data_policy.h b/src/v/kafka/server/handlers/details/data_policy.h index f887e8efa3db..ec5cf65e4310 100644 --- a/src/v/kafka/server/handlers/details/data_policy.h +++ b/src/v/kafka/server/handlers/details/data_policy.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/details/leader_epoch.h b/src/v/kafka/server/handlers/details/leader_epoch.h index 8f034d512297..f924f25c438b 100644 --- a/src/v/kafka/server/handlers/details/leader_epoch.h +++ b/src/v/kafka/server/handlers/details/leader_epoch.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/details/security.h b/src/v/kafka/server/handlers/details/security.h index 103ec9e5e7c1..0bc62add3f52 100644 --- a/src/v/kafka/server/handlers/details/security.h +++ b/src/v/kafka/server/handlers/details/security.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/end_txn.h b/src/v/kafka/server/handlers/end_txn.h index 41c8beb0a5ec..72362cb00fed 100644 --- a/src/v/kafka/server/handlers/end_txn.h +++ b/src/v/kafka/server/handlers/end_txn.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/fetch.h b/src/v/kafka/server/handlers/fetch.h index f02affa958ca..b9ccc4bbd0c6 100644 --- a/src/v/kafka/server/handlers/fetch.h +++ b/src/v/kafka/server/handlers/fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/find_coordinator.h b/src/v/kafka/server/handlers/find_coordinator.h index 93341a4c7307..8e3d83bfe4d6 100644 --- a/src/v/kafka/server/handlers/find_coordinator.h +++ b/src/v/kafka/server/handlers/find_coordinator.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/handler.h b/src/v/kafka/server/handlers/handler.h index 61fbd120dc82..17db525e9c01 100644 --- a/src/v/kafka/server/handlers/handler.h +++ b/src/v/kafka/server/handlers/handler.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/handlers.h b/src/v/kafka/server/handlers/handlers.h index 77a22207c6b5..2ece43f7ca91 100644 --- a/src/v/kafka/server/handlers/handlers.h +++ b/src/v/kafka/server/handlers/handlers.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/heartbeat.h b/src/v/kafka/server/handlers/heartbeat.h index 3dea565483ae..27a4c22b1cbd 100644 --- a/src/v/kafka/server/handlers/heartbeat.h +++ b/src/v/kafka/server/handlers/heartbeat.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/incremental_alter_configs.h b/src/v/kafka/server/handlers/incremental_alter_configs.h index 89b100f1be02..8e902f5da6b3 100644 --- a/src/v/kafka/server/handlers/incremental_alter_configs.h +++ b/src/v/kafka/server/handlers/incremental_alter_configs.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/init_producer_id.h b/src/v/kafka/server/handlers/init_producer_id.h index 826e6f823a06..5068f4325684 100644 --- a/src/v/kafka/server/handlers/init_producer_id.h +++ b/src/v/kafka/server/handlers/init_producer_id.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/join_group.h b/src/v/kafka/server/handlers/join_group.h index 6df43e2e3d5c..8e867dfcc711 100644 --- a/src/v/kafka/server/handlers/join_group.h +++ b/src/v/kafka/server/handlers/join_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/leave_group.h b/src/v/kafka/server/handlers/leave_group.h index 252c943d0f8f..19fcb5dba594 100644 --- a/src/v/kafka/server/handlers/leave_group.h +++ b/src/v/kafka/server/handlers/leave_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/list_groups.h b/src/v/kafka/server/handlers/list_groups.h index e0ba0552ef76..efe1657ae082 100644 --- a/src/v/kafka/server/handlers/list_groups.h +++ b/src/v/kafka/server/handlers/list_groups.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/list_offsets.h b/src/v/kafka/server/handlers/list_offsets.h index 6452012ef78f..896d0344b42a 100644 --- a/src/v/kafka/server/handlers/list_offsets.h +++ b/src/v/kafka/server/handlers/list_offsets.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/metadata.h b/src/v/kafka/server/handlers/metadata.h index cf45c9e60f68..89445b193fd0 100644 --- a/src/v/kafka/server/handlers/metadata.h +++ b/src/v/kafka/server/handlers/metadata.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_commit.h b/src/v/kafka/server/handlers/offset_commit.h index 8882b78e380a..2355c580aeac 100644 --- a/src/v/kafka/server/handlers/offset_commit.h +++ b/src/v/kafka/server/handlers/offset_commit.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_fetch.h b/src/v/kafka/server/handlers/offset_fetch.h index 436915a02184..fd35c5ec454a 100644 --- a/src/v/kafka/server/handlers/offset_fetch.h +++ b/src/v/kafka/server/handlers/offset_fetch.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/offset_for_leader_epoch.h b/src/v/kafka/server/handlers/offset_for_leader_epoch.h index be5fd90d2822..e191aabf2a4c 100644 --- a/src/v/kafka/server/handlers/offset_for_leader_epoch.h +++ b/src/v/kafka/server/handlers/offset_for_leader_epoch.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/produce.h b/src/v/kafka/server/handlers/produce.h index a8a5aa73baea..5c7b9de6ff5f 100644 --- a/src/v/kafka/server/handlers/produce.h +++ b/src/v/kafka/server/handlers/produce.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sasl_authenticate.h b/src/v/kafka/server/handlers/sasl_authenticate.h index e9439fe7a9a1..d86e3152223c 100644 --- a/src/v/kafka/server/handlers/sasl_authenticate.h +++ b/src/v/kafka/server/handlers/sasl_authenticate.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sasl_handshake.h b/src/v/kafka/server/handlers/sasl_handshake.h index 4b3242f7f912..d5a9343f939b 100644 --- a/src/v/kafka/server/handlers/sasl_handshake.h +++ b/src/v/kafka/server/handlers/sasl_handshake.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/sync_group.h b/src/v/kafka/server/handlers/sync_group.h index 2aa3c2cb67dc..17e9ee04ce20 100644 --- a/src/v/kafka/server/handlers/sync_group.h +++ b/src/v/kafka/server/handlers/sync_group.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/handlers/txn_offset_commit.h b/src/v/kafka/server/handlers/txn_offset_commit.h index 6ca209322f94..cc0fd7ff56a5 100644 --- a/src/v/kafka/server/handlers/txn_offset_commit.h +++ b/src/v/kafka/server/handlers/txn_offset_commit.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/materialized_partition.h b/src/v/kafka/server/materialized_partition.h index 336300172f16..324aa1243e26 100644 --- a/src/v/kafka/server/materialized_partition.h +++ b/src/v/kafka/server/materialized_partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/partition_proxy.cc b/src/v/kafka/server/partition_proxy.cc index def29c10c6dc..a70abc3ceccf 100644 --- a/src/v/kafka/server/partition_proxy.cc +++ b/src/v/kafka/server/partition_proxy.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/partition_proxy.h b/src/v/kafka/server/partition_proxy.h index dbbfe672a943..a57eda59f6a5 100644 --- a/src/v/kafka/server/partition_proxy.h +++ b/src/v/kafka/server/partition_proxy.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/queue_depth_monitor.h b/src/v/kafka/server/queue_depth_monitor.h index 655220b0ec0a..fd9f37ca26c5 100644 --- a/src/v/kafka/server/queue_depth_monitor.h +++ b/src/v/kafka/server/queue_depth_monitor.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/replicated_partition.cc b/src/v/kafka/server/replicated_partition.cc index 7b27832ae968..6f91205f67d4 100644 --- a/src/v/kafka/server/replicated_partition.cc +++ b/src/v/kafka/server/replicated_partition.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/kafka/server/replicated_partition.h b/src/v/kafka/server/replicated_partition.h index 71c924dd535d..461e3e7aa14d 100644 --- a/src/v/kafka/server/replicated_partition.h +++ b/src/v/kafka/server/replicated_partition.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/fwd.h b/src/v/net/fwd.h index 26b1b861b3b0..c13e12085cd3 100644 --- a/src/v/net/fwd.h +++ b/src/v/net/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/tls.cc b/src/v/net/tls.cc index 5bf749482a00..9d504515162d 100644 --- a/src/v/net/tls.cc +++ b/src/v/net/tls.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/tls.h b/src/v/net/tls.h index 241cccbc0b80..e60e97c55277 100644 --- a/src/v/net/tls.h +++ b/src/v/net/tls.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/transport.h b/src/v/net/transport.h index c699d0db304b..b77b24762439 100644 --- a/src/v/net/transport.h +++ b/src/v/net/transport.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/types.h b/src/v/net/types.h index 165bc525c47d..59e3751c020a 100644 --- a/src/v/net/types.h +++ b/src/v/net/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/error.cc b/src/v/pandaproxy/error.cc index bc85df5c8012..36b7133b1432 100644 --- a/src/v/pandaproxy/error.cc +++ b/src/v/pandaproxy/error.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/error.h b/src/v/pandaproxy/error.h index 126126ef97ea..c8f74e64c74b 100644 --- a/src/v/pandaproxy/error.h +++ b/src/v/pandaproxy/error.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/error.cc b/src/v/pandaproxy/json/error.cc index 70d25615c978..e7de1d8dda5b 100644 --- a/src/v/pandaproxy/json/error.cc +++ b/src/v/pandaproxy/json/error.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/error.h b/src/v/pandaproxy/json/error.h index 5eb05e720b50..0b2d8d947974 100644 --- a/src/v/pandaproxy/json/error.h +++ b/src/v/pandaproxy/json/error.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/exceptions.h b/src/v/pandaproxy/json/exceptions.h index 30c547eeb73b..0fb8cc0dbf97 100644 --- a/src/v/pandaproxy/json/exceptions.h +++ b/src/v/pandaproxy/json/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/requests/brokers.h b/src/v/pandaproxy/json/requests/brokers.h index 02318ddc09b2..6a0e57ef5502 100644 --- a/src/v/pandaproxy/json/requests/brokers.h +++ b/src/v/pandaproxy/json/requests/brokers.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/json/rjson_parse.h b/src/v/pandaproxy/json/rjson_parse.h index 7fc0321b7a4b..53149d7739da 100644 --- a/src/v/pandaproxy/json/rjson_parse.h +++ b/src/v/pandaproxy/json/rjson_parse.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/error.cc b/src/v/pandaproxy/parsing/error.cc index 93c1e1e66e94..215affd70658 100644 --- a/src/v/pandaproxy/parsing/error.cc +++ b/src/v/pandaproxy/parsing/error.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/error.h b/src/v/pandaproxy/parsing/error.h index 6f6b739122b8..f66030a71cbc 100644 --- a/src/v/pandaproxy/parsing/error.h +++ b/src/v/pandaproxy/parsing/error.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/exceptions.h b/src/v/pandaproxy/parsing/exceptions.h index 984d671ad124..4e2be8a41127 100644 --- a/src/v/pandaproxy/parsing/exceptions.h +++ b/src/v/pandaproxy/parsing/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/from_chars.h b/src/v/pandaproxy/parsing/from_chars.h index 7f268187b22e..b95baf409fa6 100644 --- a/src/v/pandaproxy/parsing/from_chars.h +++ b/src/v/pandaproxy/parsing/from_chars.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/httpd.h b/src/v/pandaproxy/parsing/httpd.h index b839c3f95007..c725ae5e5969 100644 --- a/src/v/pandaproxy/parsing/httpd.h +++ b/src/v/pandaproxy/parsing/httpd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/test/from_chars.cc b/src/v/pandaproxy/parsing/test/from_chars.cc index 68b78dce0514..47f7e4138699 100644 --- a/src/v/pandaproxy/parsing/test/from_chars.cc +++ b/src/v/pandaproxy/parsing/test/from_chars.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/parsing/test/httpd.cc b/src/v/pandaproxy/parsing/test/httpd.cc index 065829bfe9ee..a31766a800d9 100644 --- a/src/v/pandaproxy/parsing/test/httpd.cc +++ b/src/v/pandaproxy/parsing/test/httpd.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/api.cc b/src/v/pandaproxy/schema_registry/api.cc index 6b67c3d0585a..3afd9aa0319d 100644 --- a/src/v/pandaproxy/schema_registry/api.cc +++ b/src/v/pandaproxy/schema_registry/api.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/api.h b/src/v/pandaproxy/schema_registry/api.h index a9425868a33b..4aae4744254b 100644 --- a/src/v/pandaproxy/schema_registry/api.h +++ b/src/v/pandaproxy/schema_registry/api.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/avro.cc b/src/v/pandaproxy/schema_registry/avro.cc index 47f1abd0e16e..ffa20bf78127 100644 --- a/src/v/pandaproxy/schema_registry/avro.cc +++ b/src/v/pandaproxy/schema_registry/avro.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/avro.h b/src/v/pandaproxy/schema_registry/avro.h index 54a59e60f280..9ca50fc0367f 100644 --- a/src/v/pandaproxy/schema_registry/avro.h +++ b/src/v/pandaproxy/schema_registry/avro.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/configuration.cc b/src/v/pandaproxy/schema_registry/configuration.cc index 2cc0852fdc2f..41328f498098 100644 --- a/src/v/pandaproxy/schema_registry/configuration.cc +++ b/src/v/pandaproxy/schema_registry/configuration.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/configuration.h b/src/v/pandaproxy/schema_registry/configuration.h index 76016c7a027d..59873070fc39 100644 --- a/src/v/pandaproxy/schema_registry/configuration.h +++ b/src/v/pandaproxy/schema_registry/configuration.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/error.cc b/src/v/pandaproxy/schema_registry/error.cc index 2507b1f3a541..0b92f31d5e83 100644 --- a/src/v/pandaproxy/schema_registry/error.cc +++ b/src/v/pandaproxy/schema_registry/error.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/error.h b/src/v/pandaproxy/schema_registry/error.h index 6d49f5972d2c..9c453385a023 100644 --- a/src/v/pandaproxy/schema_registry/error.h +++ b/src/v/pandaproxy/schema_registry/error.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/errors.h b/src/v/pandaproxy/schema_registry/errors.h index 6ef47d9b7d7d..cc7537bd973a 100644 --- a/src/v/pandaproxy/schema_registry/errors.h +++ b/src/v/pandaproxy/schema_registry/errors.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/exceptions.h b/src/v/pandaproxy/schema_registry/exceptions.h index 7b44812c9515..50b659daeed2 100644 --- a/src/v/pandaproxy/schema_registry/exceptions.h +++ b/src/v/pandaproxy/schema_registry/exceptions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/fwd.h b/src/v/pandaproxy/schema_registry/fwd.h index 20cf63375a59..af2a81333877 100644 --- a/src/v/pandaproxy/schema_registry/fwd.h +++ b/src/v/pandaproxy/schema_registry/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/handlers.cc b/src/v/pandaproxy/schema_registry/handlers.cc index 0789e3206413..45425106b1f3 100644 --- a/src/v/pandaproxy/schema_registry/handlers.cc +++ b/src/v/pandaproxy/schema_registry/handlers.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/handlers.h b/src/v/pandaproxy/schema_registry/handlers.h index 8373493d38f9..7e4b6f91e6a8 100644 --- a/src/v/pandaproxy/schema_registry/handlers.h +++ b/src/v/pandaproxy/schema_registry/handlers.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/protobuf.cc b/src/v/pandaproxy/schema_registry/protobuf.cc index e5f381abce5b..0cb266bbdd46 100644 --- a/src/v/pandaproxy/schema_registry/protobuf.cc +++ b/src/v/pandaproxy/schema_registry/protobuf.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/protobuf.h b/src/v/pandaproxy/schema_registry/protobuf.h index e5158c903e43..edbc6aaf65c3 100644 --- a/src/v/pandaproxy/schema_registry/protobuf.h +++ b/src/v/pandaproxy/schema_registry/protobuf.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/compatibility.h b/src/v/pandaproxy/schema_registry/requests/compatibility.h index 8d92b7ad682a..db9759f51522 100644 --- a/src/v/pandaproxy/schema_registry/requests/compatibility.h +++ b/src/v/pandaproxy/schema_registry/requests/compatibility.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/config.h b/src/v/pandaproxy/schema_registry/requests/config.h index a3248e54de64..d219ad6cfa02 100644 --- a/src/v/pandaproxy/schema_registry/requests/config.h +++ b/src/v/pandaproxy/schema_registry/requests/config.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id.h b/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id.h index b36b1222cbb4..5e15b7877d9c 100644 --- a/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id.h +++ b/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id_versions.h b/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id_versions.h index 775f6ab25968..a58ac6b0be1f 100644 --- a/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id_versions.h +++ b/src/v/pandaproxy/schema_registry/requests/get_schemas_ids_id_versions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/get_subject_versions_version.h b/src/v/pandaproxy/schema_registry/requests/get_subject_versions_version.h index 94fddc653dec..18aa3e44266a 100644 --- a/src/v/pandaproxy/schema_registry/requests/get_subject_versions_version.h +++ b/src/v/pandaproxy/schema_registry/requests/get_subject_versions_version.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/post_subject_versions.h b/src/v/pandaproxy/schema_registry/requests/post_subject_versions.h index 339aef7a76a2..73e5654e0e7f 100644 --- a/src/v/pandaproxy/schema_registry/requests/post_subject_versions.h +++ b/src/v/pandaproxy/schema_registry/requests/post_subject_versions.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/test/get_subject_versions_version.cc b/src/v/pandaproxy/schema_registry/requests/test/get_subject_versions_version.cc index 7e11885d8b62..996b7b71aac1 100644 --- a/src/v/pandaproxy/schema_registry/requests/test/get_subject_versions_version.cc +++ b/src/v/pandaproxy/schema_registry/requests/test/get_subject_versions_version.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/requests/test/post_subject_versions.cc b/src/v/pandaproxy/schema_registry/requests/test/post_subject_versions.cc index 599b60e38f67..2c3aff1a8824 100644 --- a/src/v/pandaproxy/schema_registry/requests/test/post_subject_versions.cc +++ b/src/v/pandaproxy/schema_registry/requests/test/post_subject_versions.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/seq_writer.cc b/src/v/pandaproxy/schema_registry/seq_writer.cc index 628f4423629f..420f92790dd9 100644 --- a/src/v/pandaproxy/schema_registry/seq_writer.cc +++ b/src/v/pandaproxy/schema_registry/seq_writer.cc @@ -1,4 +1,4 @@ -//// Copyright 2021 Vectorized, Inc. +//// Copyright 2021 Redpanda Data, Inc. //// //// Use of this software is governed by the Business Source License //// included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/seq_writer.h b/src/v/pandaproxy/schema_registry/seq_writer.h index b84ba937cc47..12742763147a 100644 --- a/src/v/pandaproxy/schema_registry/seq_writer.h +++ b/src/v/pandaproxy/schema_registry/seq_writer.h @@ -1,4 +1,4 @@ -//// Copyright 2021 Vectorized, Inc. +//// Copyright 2021 Redpanda Data, Inc. //// //// Use of this software is governed by the Business Source License //// included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/service.cc b/src/v/pandaproxy/schema_registry/service.cc index 8c11f43577ec..577418294b4f 100644 --- a/src/v/pandaproxy/schema_registry/service.cc +++ b/src/v/pandaproxy/schema_registry/service.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/service.h b/src/v/pandaproxy/schema_registry/service.h index a6eab41166ab..8870d1c8edb7 100644 --- a/src/v/pandaproxy/schema_registry/service.h +++ b/src/v/pandaproxy/schema_registry/service.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/sharded_store.cc b/src/v/pandaproxy/schema_registry/sharded_store.cc index e4e1cf079f9e..a98b22882f6d 100644 --- a/src/v/pandaproxy/schema_registry/sharded_store.cc +++ b/src/v/pandaproxy/schema_registry/sharded_store.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/sharded_store.h b/src/v/pandaproxy/schema_registry/sharded_store.h index e9f1ec15fea0..87ff68afd603 100644 --- a/src/v/pandaproxy/schema_registry/sharded_store.h +++ b/src/v/pandaproxy/schema_registry/sharded_store.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/storage.h b/src/v/pandaproxy/schema_registry/storage.h index 5f63d14cfbb1..13914d5a0f60 100644 --- a/src/v/pandaproxy/schema_registry/storage.h +++ b/src/v/pandaproxy/schema_registry/storage.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/store.h b/src/v/pandaproxy/schema_registry/store.h index fbdf8fcc352b..f4397c428170 100644 --- a/src/v/pandaproxy/schema_registry/store.h +++ b/src/v/pandaproxy/schema_registry/store.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/avro_payloads.h b/src/v/pandaproxy/schema_registry/test/avro_payloads.h index 7a7a96ab42e1..556af0089042 100644 --- a/src/v/pandaproxy/schema_registry/test/avro_payloads.h +++ b/src/v/pandaproxy/schema_registry/test/avro_payloads.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/client_utils.h b/src/v/pandaproxy/schema_registry/test/client_utils.h index 3585b224011f..c605dda23fb7 100644 --- a/src/v/pandaproxy/schema_registry/test/client_utils.h +++ b/src/v/pandaproxy/schema_registry/test/client_utils.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_3rdparty.cc b/src/v/pandaproxy/schema_registry/test/compatibility_3rdparty.cc index 213760f33953..b2cdf9f7db78 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_3rdparty.cc +++ b/src/v/pandaproxy/schema_registry/test/compatibility_3rdparty.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_avro.cc b/src/v/pandaproxy/schema_registry/test/compatibility_avro.cc index f93d865082b3..c5975498223c 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_avro.cc +++ b/src/v/pandaproxy/schema_registry/test/compatibility_avro.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_avro.h b/src/v/pandaproxy/schema_registry/test/compatibility_avro.h index 96ca0270ca27..acd1c6733e90 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_avro.h +++ b/src/v/pandaproxy/schema_registry/test/compatibility_avro.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.cc b/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.cc index 0803d5703e93..a5832fed7491 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.cc +++ b/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.h b/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.h index ba8bd1e3b6b9..61f74c9b8b9f 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.h +++ b/src/v/pandaproxy/schema_registry/test/compatibility_protobuf.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/compatibility_store.cc b/src/v/pandaproxy/schema_registry/test/compatibility_store.cc index e4ecc21dcb81..ffd6dd51327e 100644 --- a/src/v/pandaproxy/schema_registry/test/compatibility_store.cc +++ b/src/v/pandaproxy/schema_registry/test/compatibility_store.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/consume_to_store.cc b/src/v/pandaproxy/schema_registry/test/consume_to_store.cc index 2fd51685a092..565a7af080fb 100644 --- a/src/v/pandaproxy/schema_registry/test/consume_to_store.cc +++ b/src/v/pandaproxy/schema_registry/test/consume_to_store.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/one_shot.cc b/src/v/pandaproxy/schema_registry/test/one_shot.cc index ec8a4d61a6e4..2caad0f8804f 100644 --- a/src/v/pandaproxy/schema_registry/test/one_shot.cc +++ b/src/v/pandaproxy/schema_registry/test/one_shot.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/sanitize_avro.cc b/src/v/pandaproxy/schema_registry/test/sanitize_avro.cc index d37cc575964f..4714f6b17fbb 100644 --- a/src/v/pandaproxy/schema_registry/test/sanitize_avro.cc +++ b/src/v/pandaproxy/schema_registry/test/sanitize_avro.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/sharded_store.cc b/src/v/pandaproxy/schema_registry/test/sharded_store.cc index ac2cf9920d73..c665c8005dd3 100644 --- a/src/v/pandaproxy/schema_registry/test/sharded_store.cc +++ b/src/v/pandaproxy/schema_registry/test/sharded_store.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/storage.cc b/src/v/pandaproxy/schema_registry/test/storage.cc index 8d7b67522b77..d75714876053 100644 --- a/src/v/pandaproxy/schema_registry/test/storage.cc +++ b/src/v/pandaproxy/schema_registry/test/storage.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/store.cc b/src/v/pandaproxy/schema_registry/test/store.cc index 0f60552384b5..36b6c675053e 100644 --- a/src/v/pandaproxy/schema_registry/test/store.cc +++ b/src/v/pandaproxy/schema_registry/test/store.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/test/util.cc b/src/v/pandaproxy/schema_registry/test/util.cc index cc780f522804..d5bbc282833b 100644 --- a/src/v/pandaproxy/schema_registry/test/util.cc +++ b/src/v/pandaproxy/schema_registry/test/util.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/types.cc b/src/v/pandaproxy/schema_registry/types.cc index 4fdbac402ca9..69ecb8dbec49 100644 --- a/src/v/pandaproxy/schema_registry/types.cc +++ b/src/v/pandaproxy/schema_registry/types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/types.h b/src/v/pandaproxy/schema_registry/types.h index 51591309f2ed..4e0ce0015e61 100644 --- a/src/v/pandaproxy/schema_registry/types.h +++ b/src/v/pandaproxy/schema_registry/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/pandaproxy/schema_registry/util.h b/src/v/pandaproxy/schema_registry/util.h index d71b5b65c4a4..d1880182dffc 100644 --- a/src/v/pandaproxy/schema_registry/util.h +++ b/src/v/pandaproxy/schema_registry/util.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/offset_translator.cc b/src/v/raft/offset_translator.cc index 03068ef98a49..6371494827f4 100644 --- a/src/v/raft/offset_translator.cc +++ b/src/v/raft/offset_translator.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/raft/offset_translator.h b/src/v/raft/offset_translator.h index 234d9b61a12a..bb16ef21c73c 100644 --- a/src/v/raft/offset_translator.h +++ b/src/v/raft/offset_translator.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/absl/btree_map.h b/src/v/reflection/absl/btree_map.h index 74261ceb16e5..b95599283120 100644 --- a/src/v/reflection/absl/btree_map.h +++ b/src/v/reflection/absl/btree_map.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/absl/flat_hash_map.h b/src/v/reflection/absl/flat_hash_map.h index c6b97667a6ba..224a373809d1 100644 --- a/src/v/reflection/absl/flat_hash_map.h +++ b/src/v/reflection/absl/flat_hash_map.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/absl/node_hash_map.h b/src/v/reflection/absl/node_hash_map.h index 8ffb8875bc4b..402f511af5ac 100644 --- a/src/v/reflection/absl/node_hash_map.h +++ b/src/v/reflection/absl/node_hash_map.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/seastar/circular_buffer.h b/src/v/reflection/seastar/circular_buffer.h index ea8b640556b2..3865f755dff2 100644 --- a/src/v/reflection/seastar/circular_buffer.h +++ b/src/v/reflection/seastar/circular_buffer.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/std/map.h b/src/v/reflection/std/map.h index 64f1110d3c04..9e632dd867d7 100644 --- a/src/v/reflection/std/map.h +++ b/src/v/reflection/std/map.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/std/unordered_map.h b/src/v/reflection/std/unordered_map.h index 7aac12381aad..ab0f2d170cb5 100644 --- a/src/v/reflection/std/unordered_map.h +++ b/src/v/reflection/std/unordered_map.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/reflection/std/vector.h b/src/v/reflection/std/vector.h index e6380ef42d36..74b350b4a3f8 100644 --- a/src/v/reflection/std/vector.h +++ b/src/v/reflection/std/vector.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/rpc/fwd.h b/src/v/rpc/fwd.h index 150bed3469b1..18a900eecf2b 100644 --- a/src/v/rpc/fwd.h +++ b/src/v/rpc/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/acl.h b/src/v/security/acl.h index 77261162efb0..c5671c9988a6 100644 --- a/src/v/security/acl.h +++ b/src/v/security/acl.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/acl_store.cc b/src/v/security/acl_store.cc index 6a2afaf3dfe5..c039b29a57d6 100644 --- a/src/v/security/acl_store.cc +++ b/src/v/security/acl_store.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/acl_store.h b/src/v/security/acl_store.h index 4199287858e5..a09fa2b06d5a 100644 --- a/src/v/security/acl_store.h +++ b/src/v/security/acl_store.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/authorizer.h b/src/v/security/authorizer.h index f57596f37ad7..3de2a7802c85 100644 --- a/src/v/security/authorizer.h +++ b/src/v/security/authorizer.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/scram_credential.cc b/src/v/security/scram_credential.cc index fe5a11556313..7954fbfac679 100644 --- a/src/v/security/scram_credential.cc +++ b/src/v/security/scram_credential.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/security/scram_credential.h b/src/v/security/scram_credential.h index 0bbc13ed5081..36c0c1b2abc1 100644 --- a/src/v/security/scram_credential.h +++ b/src/v/security/scram_credential.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/serde/envelope.h b/src/v/serde/envelope.h index 91d1a1a2b25c..519e327f042c 100644 --- a/src/v/serde/envelope.h +++ b/src/v/serde/envelope.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/envelope_for_each_field.h b/src/v/serde/envelope_for_each_field.h index 4f8d677220ab..772c4f12397f 100644 --- a/src/v/serde/envelope_for_each_field.h +++ b/src/v/serde/envelope_for_each_field.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/logger.h b/src/v/serde/logger.h index 209ece5c0b89..4dea7df94f58 100644 --- a/src/v/serde/logger.h +++ b/src/v/serde/logger.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/serde.h b/src/v/serde/serde.h index 41808855778b..d55773a5a1dd 100644 --- a/src/v/serde/serde.h +++ b/src/v/serde/serde.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/serde_exception.h b/src/v/serde/serde_exception.h index 5e82cb1c015a..c75931c74db8 100644 --- a/src/v/serde/serde_exception.h +++ b/src/v/serde/serde_exception.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/test/serde_test.cc b/src/v/serde/test/serde_test.cc index 6713b9e14786..51bd24f74203 100644 --- a/src/v/serde/test/serde_test.cc +++ b/src/v/serde/test/serde_test.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/serde/type_str.h b/src/v/serde/type_str.h index 7f17c1f9772b..fc3df3a679a3 100644 --- a/src/v/serde/type_str.h +++ b/src/v/serde/type_str.h @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/storage/index_state_serde_compat.h b/src/v/storage/index_state_serde_compat.h index 7e80a109eb3c..f23394d83a9b 100644 --- a/src/v/storage/index_state_serde_compat.h +++ b/src/v/storage/index_state_serde_compat.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/offset_translator_state.cc b/src/v/storage/offset_translator_state.cc index 1ae729e11456..b8c33e174755 100644 --- a/src/v/storage/offset_translator_state.cc +++ b/src/v/storage/offset_translator_state.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/offset_translator_state.h b/src/v/storage/offset_translator_state.h index 0e8a710493f8..3ed55025a4ac 100644 --- a/src/v/storage/offset_translator_state.h +++ b/src/v/storage/offset_translator_state.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/storage/translating_reader.h b/src/v/storage/translating_reader.h index e5dcbc32ed8c..9455cd51195d 100644 --- a/src/v/storage/translating_reader.h +++ b/src/v/storage/translating_reader.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/ema.h b/src/v/utils/ema.h index 3c32960a1fa1..43fb428650d3 100644 --- a/src/v/utils/ema.h +++ b/src/v/utils/ema.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/gate_guard.h b/src/v/utils/gate_guard.h index bf7e935eaffa..e910954cd763 100644 --- a/src/v/utils/gate_guard.h +++ b/src/v/utils/gate_guard.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/moving_average.h b/src/v/utils/moving_average.h index 785aac447e95..06a5413d085f 100644 --- a/src/v/utils/moving_average.h +++ b/src/v/utils/moving_average.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/prefix_logger.h b/src/v/utils/prefix_logger.h index 977405e38086..91cf3024a422 100644 --- a/src/v/utils/prefix_logger.h +++ b/src/v/utils/prefix_logger.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/stream_utils.h b/src/v/utils/stream_utils.h index 21ad01c6d581..506c462edeea 100644 --- a/src/v/utils/stream_utils.h +++ b/src/v/utils/stream_utils.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/tests/fragmented_vector_test.cc b/src/v/utils/tests/fragmented_vector_test.cc index 4940499c4764..8da37ec08659 100644 --- a/src/v/utils/tests/fragmented_vector_test.cc +++ b/src/v/utils/tests/fragmented_vector_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/tests/human_test.cc b/src/v/utils/tests/human_test.cc index 55968579eba5..eeaa13a1a1bb 100644 --- a/src/v/utils/tests/human_test.cc +++ b/src/v/utils/tests/human_test.cc @@ -1,4 +1,4 @@ -// Copyright 2021 Vectorized, Inc. +// Copyright 2021 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/tests/input_stream_fanout_test.cc b/src/v/utils/tests/input_stream_fanout_test.cc index cf907db331b3..a85abc482362 100644 --- a/src/v/utils/tests/input_stream_fanout_test.cc +++ b/src/v/utils/tests/input_stream_fanout_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/v8_engine/data_policy.cc b/src/v/v8_engine/data_policy.cc index e93a8dd3b96c..6515dc139646 100644 --- a/src/v/v8_engine/data_policy.cc +++ b/src/v/v8_engine/data_policy.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/data_policy.h b/src/v/v8_engine/data_policy.h index 836d11c8500d..5ca9759fa409 100644 --- a/src/v/v8_engine/data_policy.h +++ b/src/v/v8_engine/data_policy.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/data_policy_table.cc b/src/v/v8_engine/data_policy_table.cc index 82281a7832b3..e2d846a38b8c 100644 --- a/src/v/v8_engine/data_policy_table.cc +++ b/src/v/v8_engine/data_policy_table.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/data_policy_table.h b/src/v/v8_engine/data_policy_table.h index 0668f52b0e1f..391aa913eb7d 100644 --- a/src/v/v8_engine/data_policy_table.h +++ b/src/v/v8_engine/data_policy_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/fwd.h b/src/v/v8_engine/fwd.h index fb1129a7cd96..404305c05647 100644 --- a/src/v/v8_engine/fwd.h +++ b/src/v/v8_engine/fwd.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/v8_engine/internal/environment.cc b/src/v/v8_engine/internal/environment.cc index 09cfaf784d6b..ec4eeead2453 100644 --- a/src/v/v8_engine/internal/environment.cc +++ b/src/v/v8_engine/internal/environment.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/environment.h b/src/v/v8_engine/internal/environment.h index 00f3988bf6a5..9cf5d2801346 100644 --- a/src/v/v8_engine/internal/environment.h +++ b/src/v/v8_engine/internal/environment.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/executor.cc b/src/v/v8_engine/internal/executor.cc index 58618a9e32f7..244f2669d7bd 100644 --- a/src/v/v8_engine/internal/executor.cc +++ b/src/v/v8_engine/internal/executor.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/executor.h b/src/v/v8_engine/internal/executor.h index 35e50ef02cbe..542cd0b66fb0 100644 --- a/src/v/v8_engine/internal/executor.h +++ b/src/v/v8_engine/internal/executor.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/script.cc b/src/v/v8_engine/internal/script.cc index 20123cfc1e19..bf8385ef2a99 100644 --- a/src/v/v8_engine/internal/script.cc +++ b/src/v/v8_engine/internal/script.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/script.h b/src/v/v8_engine/internal/script.h index a14abc503b1c..352c48ac281e 100644 --- a/src/v/v8_engine/internal/script.h +++ b/src/v/v8_engine/internal/script.h @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/tests/executor_test.cc b/src/v/v8_engine/internal/tests/executor_test.cc index 13080c7b8a46..da418e26f4f2 100644 --- a/src/v/v8_engine/internal/tests/executor_test.cc +++ b/src/v/v8_engine/internal/tests/executor_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/v8_engine/internal/tests/script_test.cc b/src/v/v8_engine/internal/tests/script_test.cc index c5696f8bcc35..26ef67ed7c86 100644 --- a/src/v/v8_engine/internal/tests/script_test.cc +++ b/src/v/v8_engine/internal/tests/script_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2021 Vectorized, Inc. + * Copyright 2021 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tests/rptest/clients/kcl.py b/tests/rptest/clients/kcl.py index 4151779137fa..c2012024135e 100644 --- a/tests/rptest/clients/kcl.py +++ b/tests/rptest/clients/kcl.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/rpk_remote.py b/tests/rptest/clients/rpk_remote.py index e56868b3620a..6b93906e8a2e 100644 --- a/tests/rptest/clients/rpk_remote.py +++ b/tests/rptest/clients/rpk_remote.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/types.py b/tests/rptest/clients/types.py index 7a3ff4ed1658..686fb09a8e3f 100644 --- a/tests/rptest/clients/types.py +++ b/tests/rptest/clients/types.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/admin.py b/tests/rptest/services/admin.py index de1fb603608b..dc31a89fee51 100644 --- a/tests/rptest/services/admin.py +++ b/tests/rptest/services/admin.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/cluster.py b/tests/rptest/services/cluster.py index ef2a56f8b1fb..aa8a660c198c 100644 --- a/tests/rptest/services/cluster.py +++ b/tests/rptest/services/cluster.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/example_base.py b/tests/rptest/services/compatibility/example_base.py index 246e2eb674a8..b570023e7de7 100644 --- a/tests/rptest/services/compatibility/example_base.py +++ b/tests/rptest/services/compatibility/example_base.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/example_runner.py b/tests/rptest/services/compatibility/example_runner.py index 2777528dc807..dc43ef59745b 100644 --- a/tests/rptest/services/compatibility/example_runner.py +++ b/tests/rptest/services/compatibility/example_runner.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/franzgo_examples.py b/tests/rptest/services/compatibility/franzgo_examples.py index 17fd264e534e..6a394d4d9eef 100644 --- a/tests/rptest/services/compatibility/franzgo_examples.py +++ b/tests/rptest/services/compatibility/franzgo_examples.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/kafka_streams_examples.py b/tests/rptest/services/compatibility/kafka_streams_examples.py index 6002d1e20a69..c4c4af27145a 100644 --- a/tests/rptest/services/compatibility/kafka_streams_examples.py +++ b/tests/rptest/services/compatibility/kafka_streams_examples.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/compatibility/sarama_examples.py b/tests/rptest/services/compatibility/sarama_examples.py index 2893cdabb761..292373c35238 100644 --- a/tests/rptest/services/compatibility/sarama_examples.py +++ b/tests/rptest/services/compatibility/sarama_examples.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/honey_badger.py b/tests/rptest/services/honey_badger.py index c0341ec55b54..a607ba6590c2 100644 --- a/tests/rptest/services/honey_badger.py +++ b/tests/rptest/services/honey_badger.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/test_suite_rpk.yml b/tests/rptest/test_suite_rpk.yml index 995ef9a84fa3..07041744ba82 100644 --- a/tests/rptest/test_suite_rpk.yml +++ b/tests/rptest/test_suite_rpk.yml @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/acls_test.py b/tests/rptest/tests/acls_test.py index afc60017dd85..19fa8896ac05 100644 --- a/tests/rptest/tests/acls_test.py +++ b/tests/rptest/tests/acls_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/archival_test.py b/tests/rptest/tests/archival_test.py index 8b62b85048b7..56629c355553 100644 --- a/tests/rptest/tests/archival_test.py +++ b/tests/rptest/tests/archival_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Licensed as a Redpanda Enterprise file under the Redpanda Community # License (the "License"); you may not use this file except in compliance with diff --git a/tests/rptest/tests/bytes_sent_test.py b/tests/rptest/tests/bytes_sent_test.py index e79c08918b18..85981e529782 100644 --- a/tests/rptest/tests/bytes_sent_test.py +++ b/tests/rptest/tests/bytes_sent_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/cluster_features_test.py b/tests/rptest/tests/cluster_features_test.py index a15aa2a04ca9..24d97691a628 100644 --- a/tests/rptest/tests/cluster_features_test.py +++ b/tests/rptest/tests/cluster_features_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compatibility/franzgo_test.py b/tests/rptest/tests/compatibility/franzgo_test.py index e35e04f7cf74..62f9400a5096 100644 --- a/tests/rptest/tests/compatibility/franzgo_test.py +++ b/tests/rptest/tests/compatibility/franzgo_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compatibility/kafka_streams_test.py b/tests/rptest/tests/compatibility/kafka_streams_test.py index ebdc774aaf62..1587b7c5b24b 100644 --- a/tests/rptest/tests/compatibility/kafka_streams_test.py +++ b/tests/rptest/tests/compatibility/kafka_streams_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/compatibility/sarama_test.py b/tests/rptest/tests/compatibility/sarama_test.py index e52fc73f46e2..b2d7814ed403 100644 --- a/tests/rptest/tests/compatibility/sarama_test.py +++ b/tests/rptest/tests/compatibility/sarama_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/data_policy_test.py b/tests/rptest/tests/data_policy_test.py index a0cc8f9477b5..7cfe7eddec97 100644 --- a/tests/rptest/tests/data_policy_test.py +++ b/tests/rptest/tests/data_policy_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/e2e_shadow_indexing_test.py b/tests/rptest/tests/e2e_shadow_indexing_test.py index fcd4d0227b55..992b6d3d2837 100644 --- a/tests/rptest/tests/e2e_shadow_indexing_test.py +++ b/tests/rptest/tests/e2e_shadow_indexing_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/group_membership_test.py b/tests/rptest/tests/group_membership_test.py index 2b1bd880efb8..81c52e88aa73 100644 --- a/tests/rptest/tests/group_membership_test.py +++ b/tests/rptest/tests/group_membership_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/offset_for_leader_epoch_archival_test.py b/tests/rptest/tests/offset_for_leader_epoch_archival_test.py index f44f2c81e2ba..7c937c547c96 100644 --- a/tests/rptest/tests/offset_for_leader_epoch_archival_test.py +++ b/tests/rptest/tests/offset_for_leader_epoch_archival_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/offset_for_leader_epoch_test.py b/tests/rptest/tests/offset_for_leader_epoch_test.py index 32d1517c9467..6759b54209f8 100644 --- a/tests/rptest/tests/offset_for_leader_epoch_test.py +++ b/tests/rptest/tests/offset_for_leader_epoch_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/partition_metrics_test.py b/tests/rptest/tests/partition_metrics_test.py index 5ca6e2e97c5b..820c5b49541c 100644 --- a/tests/rptest/tests/partition_metrics_test.py +++ b/tests/rptest/tests/partition_metrics_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/resource_limits_test.py b/tests/rptest/tests/resource_limits_test.py index 0d84e987d516..166ecadadb30 100644 --- a/tests/rptest/tests/resource_limits_test.py +++ b/tests/rptest/tests/resource_limits_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/rpk_cluster_test.py b/tests/rptest/tests/rpk_cluster_test.py index 136cc241747a..4df7b9be69cc 100644 --- a/tests/rptest/tests/rpk_cluster_test.py +++ b/tests/rptest/tests/rpk_cluster_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/rpk_config_test.py b/tests/rptest/tests/rpk_config_test.py index e1ef4e6ba9a8..04ab14608629 100644 --- a/tests/rptest/tests/rpk_config_test.py +++ b/tests/rptest/tests/rpk_config_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/schema_registry_test.py b/tests/rptest/tests/schema_registry_test.py index 4fbc9c9a01da..590568b80df2 100644 --- a/tests/rptest/tests/schema_registry_test.py +++ b/tests/rptest/tests/schema_registry_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/shadow_indexing_tx_test.py b/tests/rptest/tests/shadow_indexing_tx_test.py index 04071c981a23..26bb96ea1d9c 100644 --- a/tests/rptest/tests/shadow_indexing_tx_test.py +++ b/tests/rptest/tests/shadow_indexing_tx_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/topic_autocreate_test.py b/tests/rptest/tests/topic_autocreate_test.py index bbfa430f2055..683fae2206b5 100644 --- a/tests/rptest/tests/topic_autocreate_test.py +++ b/tests/rptest/tests/topic_autocreate_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/topic_recovery_test.py b/tests/rptest/tests/topic_recovery_test.py index 0a9116966863..f880d60e8c27 100644 --- a/tests/rptest/tests/topic_recovery_test.py +++ b/tests/rptest/tests/topic_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Licensed as a Redpanda Enterprise file under the Redpanda Community # License (the "License"); you may not use this file except in compliance with diff --git a/tests/rptest/tests/tx_admin_api_test.py b/tests/rptest/tests/tx_admin_api_test.py index f675e68061f8..a33ab5f631a6 100644 --- a/tests/rptest/tests/tx_admin_api_test.py +++ b/tests/rptest/tests/tx_admin_api_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wasm_filter_test.py b/tests/rptest/tests/wasm_filter_test.py index 62a192f686f3..0e680059aa22 100644 --- a/tests/rptest/tests/wasm_filter_test.py +++ b/tests/rptest/tests/wasm_filter_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wasm_identity_test.py b/tests/rptest/tests/wasm_identity_test.py index 0102d93496ce..9c80dfadf40d 100644 --- a/tests/rptest/tests/wasm_identity_test.py +++ b/tests/rptest/tests/wasm_identity_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wasm_partition_movement_test.py b/tests/rptest/tests/wasm_partition_movement_test.py index 4130535c70af..c4b7e02245f6 100644 --- a/tests/rptest/tests/wasm_partition_movement_test.py +++ b/tests/rptest/tests/wasm_partition_movement_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wasm_redpanda_failure_recovery_test.py b/tests/rptest/tests/wasm_redpanda_failure_recovery_test.py index 7b0b729b91ca..7d3f6615357c 100644 --- a/tests/rptest/tests/wasm_redpanda_failure_recovery_test.py +++ b/tests/rptest/tests/wasm_redpanda_failure_recovery_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/wasm_topics_test.py b/tests/rptest/tests/wasm_topics_test.py index b7cd90b71ac7..c4976e1e56c1 100644 --- a/tests/rptest/tests/wasm_topics_test.py +++ b/tests/rptest/tests/wasm_topics_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/background_task.py b/tests/rptest/wasm/background_task.py index 4c7f8a9395fc..cf8016bda3f7 100644 --- a/tests/rptest/wasm/background_task.py +++ b/tests/rptest/wasm/background_task.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/native_kafka_consumer.py b/tests/rptest/wasm/native_kafka_consumer.py index 281bb1e7350d..3c7ca7034e8e 100644 --- a/tests/rptest/wasm/native_kafka_consumer.py +++ b/tests/rptest/wasm/native_kafka_consumer.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/topic.py b/tests/rptest/wasm/topic.py index a5a50a724268..f05bde56fd37 100644 --- a/tests/rptest/wasm/topic.py +++ b/tests/rptest/wasm/topic.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/topics_result_set.py b/tests/rptest/wasm/topics_result_set.py index 0eb7079d9a00..d6b37e35a29a 100644 --- a/tests/rptest/wasm/topics_result_set.py +++ b/tests/rptest/wasm/topics_result_set.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/wasm_build_tool.py b/tests/rptest/wasm/wasm_build_tool.py index 8e38cbfee9b1..9fb3c26d5970 100644 --- a/tests/rptest/wasm/wasm_build_tool.py +++ b/tests/rptest/wasm/wasm_build_tool.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/wasm_script.py b/tests/rptest/wasm/wasm_script.py index 10828bb4639c..d57bdb550033 100644 --- a/tests/rptest/wasm/wasm_script.py +++ b/tests/rptest/wasm/wasm_script.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/wasm/wasm_test.py b/tests/rptest/wasm/wasm_test.py index 0342ff9a882b..9f8fc32370dc 100644 --- a/tests/rptest/wasm/wasm_test.py +++ b/tests/rptest/wasm/wasm_test.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tools/gen_coverage.py b/tools/gen_coverage.py index d6ce9679be01..294cf27d38a2 100644 --- a/tools/gen_coverage.py +++ b/tools/gen_coverage.py @@ -1,4 +1,4 @@ -# Copyright 2021 Vectorized, Inc. +# Copyright 2021 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md From cd2cdb9e320e553769c49a3e6ebfb4dd02c048f6 Mon Sep 17 00:00:00 2001 From: Andrew Hsu Date: Mon, 21 Mar 2022 20:50:42 +0000 Subject: [PATCH 3/5] replace vectorized with redpanda in 2022 copyright find . -type f -exec sed -i 's|Copyright 2022 Vectorized, Inc.|Copyright 2022 Redpanda Data, Inc.|g' {} \; --- src/go/k8s/apis/redpanda/v1alpha1/cluster_types_test.go | 2 +- src/go/k8s/pkg/networking/address_types.go | 2 +- src/go/k8s/pkg/networking/address_types_test.go | 2 +- src/go/k8s/pkg/resources/lb_service.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/get.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/lint.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/reset.go | 2 +- src/go/rpk/pkg/cli/cmd/cluster/config/set.go | 2 +- src/v/cloud_storage/base_manifest.h | 2 +- src/v/cloud_storage/cache_probe.cc | 2 +- src/v/cloud_storage/cache_probe.h | 2 +- src/v/cloud_storage/partition_manifest.cc | 2 +- src/v/cloud_storage/partition_manifest.h | 2 +- src/v/cloud_storage/partition_probe.cc | 2 +- src/v/cloud_storage/partition_probe.h | 2 +- src/v/cloud_storage/partition_recovery_manager.cc | 2 +- src/v/cloud_storage/partition_recovery_manager.h | 2 +- src/v/cloud_storage/recursive_directory_walker.cc | 2 +- src/v/cloud_storage/recursive_directory_walker.h | 2 +- src/v/cloud_storage/remote_segment.cc | 2 +- src/v/cloud_storage/remote_segment.h | 2 +- src/v/cloud_storage/remote_segment_index.cc | 2 +- src/v/cloud_storage/remote_segment_index.h | 2 +- src/v/cloud_storage/tests/common_def.h | 2 +- src/v/cloud_storage/tests/partition_manifest_test.cc | 2 +- src/v/cloud_storage/tests/remote_segment_index_test.cc | 2 +- src/v/cloud_storage/topic_manifest.cc | 2 +- src/v/cloud_storage/topic_manifest.h | 2 +- src/v/cloud_storage/types.cc | 2 +- src/v/cloud_storage/types.h | 2 +- src/v/cluster/drain_manager.h | 2 +- src/v/cluster/feature_backend.cc | 2 +- src/v/cluster/feature_backend.h | 2 +- src/v/cluster/feature_barrier.cc | 2 +- src/v/cluster/feature_barrier.h | 2 +- src/v/cluster/feature_manager.cc | 2 +- src/v/cluster/feature_table.h | 2 +- src/v/cluster/node/constants.h | 2 +- src/v/cluster/tests/feature_barrier_test.cc | 2 +- src/v/cluster/tests/local_monitor_fixture.h | 2 +- src/v/cluster/tests/local_monitor_test.cc | 2 +- src/v/config/bounded_property.h | 2 +- src/v/config/mock_property.h | 2 +- src/v/config/tests/bounded_property_test.cc | 2 +- src/v/config/validators.cc | 2 +- src/v/config/validators.h | 2 +- src/v/coproc/tests/pacemaker_unstable_tests.cc | 2 +- src/v/json/allocator.h | 2 +- src/v/json/document.h | 2 +- src/v/json/logger.h | 2 +- src/v/json/writer.h | 2 +- src/v/net/conn_quota.cc | 2 +- src/v/net/conn_quota.h | 2 +- src/v/net/connection_rate.cc | 2 +- src/v/net/connection_rate.h | 2 +- src/v/net/inet_address_wrapper.h | 2 +- src/v/net/tests/connection_rate_test.cc | 2 +- src/v/redpanda/request_auth.cc | 2 +- src/v/redpanda/request_auth.h | 2 +- src/v/utils/delta_for.h | 2 +- src/v/utils/tests/delta_for_test.cc | 2 +- src/v/utils/waiter_queue.h | 2 +- src/v/v8_engine/internal/tests/executor_stress_test.cc | 2 +- tests/rptest/clients/default.py | 2 +- tests/rptest/clients/python_librdkafka_serde_client.py | 2 +- tests/rptest/services/franz_go_verifiable_services.py | 2 +- tests/rptest/services/metrics_check.py | 2 +- tests/rptest/tests/connection_limits_test.py | 2 +- tests/rptest/tests/connection_rate_limit_test.py | 2 +- tests/rptest/tests/consumer_offsets_migration_test.py | 2 +- tests/rptest/tests/franz_go_verifiable_test.py | 2 +- tests/rptest/tests/maintenance_test.py | 2 +- tests/rptest/tests/many_partitions_test.py | 2 +- tests/rptest/tests/node_metrics_test.py | 2 +- tests/rptest/tests/node_resize_test.py | 2 +- tests/rptest/tests/simple_e2e_test.py | 2 +- tests/rptest/tests/tx_feature_flag_test.py | 2 +- tests/rptest/trim_results.py | 2 +- 78 files changed, 78 insertions(+), 78 deletions(-) diff --git a/src/go/k8s/apis/redpanda/v1alpha1/cluster_types_test.go b/src/go/k8s/apis/redpanda/v1alpha1/cluster_types_test.go index 1678e74ff1df..eb99858024bf 100644 --- a/src/go/k8s/apis/redpanda/v1alpha1/cluster_types_test.go +++ b/src/go/k8s/apis/redpanda/v1alpha1/cluster_types_test.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/networking/address_types.go b/src/go/k8s/pkg/networking/address_types.go index ed46829216f3..4b4fe27a82a6 100644 --- a/src/go/k8s/pkg/networking/address_types.go +++ b/src/go/k8s/pkg/networking/address_types.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/networking/address_types_test.go b/src/go/k8s/pkg/networking/address_types_test.go index b102aba637c0..37c114938721 100644 --- a/src/go/k8s/pkg/networking/address_types_test.go +++ b/src/go/k8s/pkg/networking/address_types_test.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/k8s/pkg/resources/lb_service.go b/src/go/k8s/pkg/resources/lb_service.go index aff9b2dc5fe6..8ff840985d2d 100644 --- a/src/go/k8s/pkg/resources/lb_service.go +++ b/src/go/k8s/pkg/resources/lb_service.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/get.go b/src/go/rpk/pkg/cli/cmd/cluster/config/get.go index 86f3ab1d6dcb..f96b270b01c1 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/get.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/get.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/lint.go b/src/go/rpk/pkg/cli/cmd/cluster/config/lint.go index 5f9248984ae9..c1e16024f05b 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/lint.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/lint.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/reset.go b/src/go/rpk/pkg/cli/cmd/cluster/config/reset.go index e2f61325d03d..b8e20c98ce0e 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/reset.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/reset.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/go/rpk/pkg/cli/cmd/cluster/config/set.go b/src/go/rpk/pkg/cli/cmd/cluster/config/set.go index b6cfc56af977..cc5e45f03278 100644 --- a/src/go/rpk/pkg/cli/cmd/cluster/config/set.go +++ b/src/go/rpk/pkg/cli/cmd/cluster/config/set.go @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/cloud_storage/base_manifest.h b/src/v/cloud_storage/base_manifest.h index ee1e7a4d2458..e3169cb6c897 100644 --- a/src/v/cloud_storage/base_manifest.h +++ b/src/v/cloud_storage/base_manifest.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/cache_probe.cc b/src/v/cloud_storage/cache_probe.cc index d4e975b06bed..aa7bfb46b2d2 100644 --- a/src/v/cloud_storage/cache_probe.cc +++ b/src/v/cloud_storage/cache_probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/cache_probe.h b/src/v/cloud_storage/cache_probe.h index 850a2d9013ac..f1be467f1764 100644 --- a/src/v/cloud_storage/cache_probe.h +++ b/src/v/cloud_storage/cache_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_manifest.cc b/src/v/cloud_storage/partition_manifest.cc index f27ac06f779d..fef9a08b0cbd 100644 --- a/src/v/cloud_storage/partition_manifest.cc +++ b/src/v/cloud_storage/partition_manifest.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_manifest.h b/src/v/cloud_storage/partition_manifest.h index 6e629fb311c1..d60b8f487cde 100644 --- a/src/v/cloud_storage/partition_manifest.h +++ b/src/v/cloud_storage/partition_manifest.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_probe.cc b/src/v/cloud_storage/partition_probe.cc index 2b7f042a755a..14d4b3da8742 100644 --- a/src/v/cloud_storage/partition_probe.cc +++ b/src/v/cloud_storage/partition_probe.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_probe.h b/src/v/cloud_storage/partition_probe.h index c90320cccbbe..956e952bba6b 100644 --- a/src/v/cloud_storage/partition_probe.h +++ b/src/v/cloud_storage/partition_probe.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_recovery_manager.cc b/src/v/cloud_storage/partition_recovery_manager.cc index a576cb283ac8..9ff5a171d378 100644 --- a/src/v/cloud_storage/partition_recovery_manager.cc +++ b/src/v/cloud_storage/partition_recovery_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/partition_recovery_manager.h b/src/v/cloud_storage/partition_recovery_manager.h index dc020a89adfc..3a5044ccb306 100644 --- a/src/v/cloud_storage/partition_recovery_manager.h +++ b/src/v/cloud_storage/partition_recovery_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/recursive_directory_walker.cc b/src/v/cloud_storage/recursive_directory_walker.cc index bdc0e99ce2ea..f5c5fd83092c 100644 --- a/src/v/cloud_storage/recursive_directory_walker.cc +++ b/src/v/cloud_storage/recursive_directory_walker.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/recursive_directory_walker.h b/src/v/cloud_storage/recursive_directory_walker.h index daeeea6691c2..df2e40ecfbd4 100644 --- a/src/v/cloud_storage/recursive_directory_walker.h +++ b/src/v/cloud_storage/recursive_directory_walker.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_segment.cc b/src/v/cloud_storage/remote_segment.cc index f25f1e9a0001..1b204bdd92b5 100644 --- a/src/v/cloud_storage/remote_segment.cc +++ b/src/v/cloud_storage/remote_segment.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_segment.h b/src/v/cloud_storage/remote_segment.h index b5d5d55a2b95..eb62047a6761 100644 --- a/src/v/cloud_storage/remote_segment.h +++ b/src/v/cloud_storage/remote_segment.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_segment_index.cc b/src/v/cloud_storage/remote_segment_index.cc index 43d955a29b08..f9804e89e60c 100644 --- a/src/v/cloud_storage/remote_segment_index.cc +++ b/src/v/cloud_storage/remote_segment_index.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/remote_segment_index.h b/src/v/cloud_storage/remote_segment_index.h index 7ec6a970e02c..f2e4bbac0450 100644 --- a/src/v/cloud_storage/remote_segment_index.h +++ b/src/v/cloud_storage/remote_segment_index.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/common_def.h b/src/v/cloud_storage/tests/common_def.h index f05f701d4b3d..c362400311a9 100644 --- a/src/v/cloud_storage/tests/common_def.h +++ b/src/v/cloud_storage/tests/common_def.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/partition_manifest_test.cc b/src/v/cloud_storage/tests/partition_manifest_test.cc index 1b31db77f18b..635c42805ffc 100644 --- a/src/v/cloud_storage/tests/partition_manifest_test.cc +++ b/src/v/cloud_storage/tests/partition_manifest_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/tests/remote_segment_index_test.cc b/src/v/cloud_storage/tests/remote_segment_index_test.cc index ee82259a7e8c..73485a326016 100644 --- a/src/v/cloud_storage/tests/remote_segment_index_test.cc +++ b/src/v/cloud_storage/tests/remote_segment_index_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/topic_manifest.cc b/src/v/cloud_storage/topic_manifest.cc index 3ae9e6f22ee5..7ed0a9dca256 100644 --- a/src/v/cloud_storage/topic_manifest.cc +++ b/src/v/cloud_storage/topic_manifest.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/topic_manifest.h b/src/v/cloud_storage/topic_manifest.h index f8e815ea8fbc..1def699618f0 100644 --- a/src/v/cloud_storage/topic_manifest.h +++ b/src/v/cloud_storage/topic_manifest.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/types.cc b/src/v/cloud_storage/types.cc index 421c387a483b..41a8ac46388c 100644 --- a/src/v/cloud_storage/types.cc +++ b/src/v/cloud_storage/types.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cloud_storage/types.h b/src/v/cloud_storage/types.h index dcecd7998b7c..d452588b1ece 100644 --- a/src/v/cloud_storage/types.h +++ b/src/v/cloud_storage/types.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/cluster/drain_manager.h b/src/v/cluster/drain_manager.h index e79cb6e75ca0..e5602b12b4b9 100644 --- a/src/v/cluster/drain_manager.h +++ b/src/v/cluster/drain_manager.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_backend.cc b/src/v/cluster/feature_backend.cc index 064f3df90365..4591c689b881 100644 --- a/src/v/cluster/feature_backend.cc +++ b/src/v/cluster/feature_backend.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_backend.h b/src/v/cluster/feature_backend.h index fb289ed1316d..d87159032de2 100644 --- a/src/v/cluster/feature_backend.h +++ b/src/v/cluster/feature_backend.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_barrier.cc b/src/v/cluster/feature_barrier.cc index c3a180273e5a..9bf4d54b9b9b 100644 --- a/src/v/cluster/feature_barrier.cc +++ b/src/v/cluster/feature_barrier.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_barrier.h b/src/v/cluster/feature_barrier.h index 081a7e8355c6..a09da4b6c442 100644 --- a/src/v/cluster/feature_barrier.h +++ b/src/v/cluster/feature_barrier.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_manager.cc b/src/v/cluster/feature_manager.cc index 1877876df585..0edc6a7430a0 100644 --- a/src/v/cluster/feature_manager.cc +++ b/src/v/cluster/feature_manager.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/feature_table.h b/src/v/cluster/feature_table.h index e73a3bf54d00..b4523f811f19 100644 --- a/src/v/cluster/feature_table.h +++ b/src/v/cluster/feature_table.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/node/constants.h b/src/v/cluster/node/constants.h index 1cf8c21effc4..1298878758f9 100644 --- a/src/v/cluster/node/constants.h +++ b/src/v/cluster/node/constants.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/feature_barrier_test.cc b/src/v/cluster/tests/feature_barrier_test.cc index 30a4e561f04b..ef16f662030c 100644 --- a/src/v/cluster/tests/feature_barrier_test.cc +++ b/src/v/cluster/tests/feature_barrier_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/local_monitor_fixture.h b/src/v/cluster/tests/local_monitor_fixture.h index c7e3be882ad6..749deb83226e 100644 --- a/src/v/cluster/tests/local_monitor_fixture.h +++ b/src/v/cluster/tests/local_monitor_fixture.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/cluster/tests/local_monitor_test.cc b/src/v/cluster/tests/local_monitor_test.cc index b8db16e77285..bad462f25c7b 100644 --- a/src/v/cluster/tests/local_monitor_test.cc +++ b/src/v/cluster/tests/local_monitor_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/bounded_property.h b/src/v/config/bounded_property.h index 78ff697815f2..6ffddda0389f 100644 --- a/src/v/config/bounded_property.h +++ b/src/v/config/bounded_property.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/mock_property.h b/src/v/config/mock_property.h index 604f9af66631..eedc7b5caa02 100644 --- a/src/v/config/mock_property.h +++ b/src/v/config/mock_property.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/tests/bounded_property_test.cc b/src/v/config/tests/bounded_property_test.cc index 99a043eb0b4a..41653fcc924c 100644 --- a/src/v/config/tests/bounded_property_test.cc +++ b/src/v/config/tests/bounded_property_test.cc @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/config/validators.cc b/src/v/config/validators.cc index e6435caee38d..3c4f895c7c7d 100644 --- a/src/v/config/validators.cc +++ b/src/v/config/validators.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/config/validators.h b/src/v/config/validators.h index 00bcf5d9f5da..7302cdc1c011 100644 --- a/src/v/config/validators.h +++ b/src/v/config/validators.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/coproc/tests/pacemaker_unstable_tests.cc b/src/v/coproc/tests/pacemaker_unstable_tests.cc index db7d4444bb1b..71d4aac24d6f 100644 --- a/src/v/coproc/tests/pacemaker_unstable_tests.cc +++ b/src/v/coproc/tests/pacemaker_unstable_tests.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/json/allocator.h b/src/v/json/allocator.h index 4d4dfb797a85..ddc7218c8938 100644 --- a/src/v/json/allocator.h +++ b/src/v/json/allocator.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/json/document.h b/src/v/json/document.h index 2ff54d85f9de..f25d089ad04b 100644 --- a/src/v/json/document.h +++ b/src/v/json/document.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/json/logger.h b/src/v/json/logger.h index c3f971e234ed..c7f9248a2768 100644 --- a/src/v/json/logger.h +++ b/src/v/json/logger.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/json/writer.h b/src/v/json/writer.h index e14b2c7f05c2..6dfc394f140f 100644 --- a/src/v/json/writer.h +++ b/src/v/json/writer.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/conn_quota.cc b/src/v/net/conn_quota.cc index efb27f293dbb..7ef47596363a 100644 --- a/src/v/net/conn_quota.cc +++ b/src/v/net/conn_quota.cc @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/conn_quota.h b/src/v/net/conn_quota.h index 73c3cdf02c97..4fe1600809ac 100644 --- a/src/v/net/conn_quota.h +++ b/src/v/net/conn_quota.h @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/net/connection_rate.cc b/src/v/net/connection_rate.cc index b1cee0da96ac..0f3dcfe4f8d7 100644 --- a/src/v/net/connection_rate.cc +++ b/src/v/net/connection_rate.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/connection_rate.h b/src/v/net/connection_rate.h index e6361f94f1f1..580004af033d 100644 --- a/src/v/net/connection_rate.h +++ b/src/v/net/connection_rate.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/inet_address_wrapper.h b/src/v/net/inet_address_wrapper.h index 5aa1e9016d09..bbf0339bfbf6 100644 --- a/src/v/net/inet_address_wrapper.h +++ b/src/v/net/inet_address_wrapper.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/net/tests/connection_rate_test.cc b/src/v/net/tests/connection_rate_test.cc index d8497a7fbcd7..1f3ef2471303 100644 --- a/src/v/net/tests/connection_rate_test.cc +++ b/src/v/net/tests/connection_rate_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/src/v/redpanda/request_auth.cc b/src/v/redpanda/request_auth.cc index 3ca68119d253..7cdf604ab9aa 100644 --- a/src/v/redpanda/request_auth.cc +++ b/src/v/redpanda/request_auth.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/redpanda/request_auth.h b/src/v/redpanda/request_auth.h index 65317f58a307..68d8ee86fb26 100644 --- a/src/v/redpanda/request_auth.h +++ b/src/v/redpanda/request_auth.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/delta_for.h b/src/v/utils/delta_for.h index 084d954f0c61..715d0cbf5cc4 100644 --- a/src/v/utils/delta_for.h +++ b/src/v/utils/delta_for.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/utils/tests/delta_for_test.cc b/src/v/utils/tests/delta_for_test.cc index 8f4e82333969..37cc049bb6ac 100644 --- a/src/v/utils/tests/delta_for_test.cc +++ b/src/v/utils/tests/delta_for_test.cc @@ -1,4 +1,4 @@ -// Copyright 2022 Vectorized, Inc. +// Copyright 2022 Redpanda Data, Inc. // // Use of this software is governed by the Business Source License // included in the file licenses/BSL.md diff --git a/src/v/utils/waiter_queue.h b/src/v/utils/waiter_queue.h index 1faff8561514..9fc6366891b7 100644 --- a/src/v/utils/waiter_queue.h +++ b/src/v/utils/waiter_queue.h @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Use of this software is governed by the Business Source License * included in the file licenses/BSL.md diff --git a/src/v/v8_engine/internal/tests/executor_stress_test.cc b/src/v/v8_engine/internal/tests/executor_stress_test.cc index edd3d654d72b..32c0f67a1621 100644 --- a/src/v/v8_engine/internal/tests/executor_stress_test.cc +++ b/src/v/v8_engine/internal/tests/executor_stress_test.cc @@ -1,5 +1,5 @@ /* - * Copyright 2022 Vectorized, Inc. + * Copyright 2022 Redpanda Data, Inc. * * Licensed as a Redpanda Enterprise file under the Redpanda Community * License (the "License"); you may not use this file except in compliance with diff --git a/tests/rptest/clients/default.py b/tests/rptest/clients/default.py index ef832a657c83..33e50a4cc5e8 100644 --- a/tests/rptest/clients/default.py +++ b/tests/rptest/clients/default.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/clients/python_librdkafka_serde_client.py b/tests/rptest/clients/python_librdkafka_serde_client.py index 4616f58e2f40..63da5b8cb171 100644 --- a/tests/rptest/clients/python_librdkafka_serde_client.py +++ b/tests/rptest/clients/python_librdkafka_serde_client.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/franz_go_verifiable_services.py b/tests/rptest/services/franz_go_verifiable_services.py index f776c30a2754..292e7a9c8a17 100644 --- a/tests/rptest/services/franz_go_verifiable_services.py +++ b/tests/rptest/services/franz_go_verifiable_services.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/services/metrics_check.py b/tests/rptest/services/metrics_check.py index e6e4f04e5f95..368e10db87be 100644 --- a/tests/rptest/services/metrics_check.py +++ b/tests/rptest/services/metrics_check.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/connection_limits_test.py b/tests/rptest/tests/connection_limits_test.py index f947b39bfc8b..f2799b3d6f4c 100644 --- a/tests/rptest/tests/connection_limits_test.py +++ b/tests/rptest/tests/connection_limits_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/connection_rate_limit_test.py b/tests/rptest/tests/connection_rate_limit_test.py index eb4159e79d7c..0a05949f0cc2 100644 --- a/tests/rptest/tests/connection_rate_limit_test.py +++ b/tests/rptest/tests/connection_rate_limit_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/consumer_offsets_migration_test.py b/tests/rptest/tests/consumer_offsets_migration_test.py index 56b738ae7520..8a1359f42850 100644 --- a/tests/rptest/tests/consumer_offsets_migration_test.py +++ b/tests/rptest/tests/consumer_offsets_migration_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/franz_go_verifiable_test.py b/tests/rptest/tests/franz_go_verifiable_test.py index 713a9e85be41..b972e9f2f493 100644 --- a/tests/rptest/tests/franz_go_verifiable_test.py +++ b/tests/rptest/tests/franz_go_verifiable_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/maintenance_test.py b/tests/rptest/tests/maintenance_test.py index 3f91c3b60120..1c9defb4b6f4 100644 --- a/tests/rptest/tests/maintenance_test.py +++ b/tests/rptest/tests/maintenance_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/many_partitions_test.py b/tests/rptest/tests/many_partitions_test.py index 33fb625d4857..5c47baacb3a2 100644 --- a/tests/rptest/tests/many_partitions_test.py +++ b/tests/rptest/tests/many_partitions_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/node_metrics_test.py b/tests/rptest/tests/node_metrics_test.py index fde53e454f36..71909c223616 100644 --- a/tests/rptest/tests/node_metrics_test.py +++ b/tests/rptest/tests/node_metrics_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/node_resize_test.py b/tests/rptest/tests/node_resize_test.py index 7297075fa301..9c2400f0140b 100644 --- a/tests/rptest/tests/node_resize_test.py +++ b/tests/rptest/tests/node_resize_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/simple_e2e_test.py b/tests/rptest/tests/simple_e2e_test.py index 8e11126a67e7..596ee408a779 100644 --- a/tests/rptest/tests/simple_e2e_test.py +++ b/tests/rptest/tests/simple_e2e_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/tests/tx_feature_flag_test.py b/tests/rptest/tests/tx_feature_flag_test.py index 67c07d331246..696f69096078 100644 --- a/tests/rptest/tests/tx_feature_flag_test.py +++ b/tests/rptest/tests/tx_feature_flag_test.py @@ -1,4 +1,4 @@ -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md diff --git a/tests/rptest/trim_results.py b/tests/rptest/trim_results.py index 645127809bb5..70b4c74dcaf3 100755 --- a/tests/rptest/trim_results.py +++ b/tests/rptest/trim_results.py @@ -1,6 +1,6 @@ #!/usr/bin/python3 -# Copyright 2022 Vectorized, Inc. +# Copyright 2022 Redpanda Data, Inc. # # Use of this software is governed by the Business Source License # included in the file licenses/BSL.md From 5f139db26d53fb6eef96cedde9d75a54c541c87a Mon Sep 17 00:00:00 2001 From: Andrew Hsu Date: Mon, 21 Mar 2022 20:54:40 +0000 Subject: [PATCH 4/5] update other copyright comments for redpanda --- tests/rptest/services/verifiable_consumer.py | 2 +- tests/rptest/services/verifiable_producer.py | 2 +- tests/rptest/tests/end_to_end.py | 2 +- tools/redpanda-gdb.py | 2 +- 4 files changed, 4 insertions(+), 4 deletions(-) diff --git a/tests/rptest/services/verifiable_consumer.py b/tests/rptest/services/verifiable_consumer.py index c0f1557092b7..b9b88631f744 100644 --- a/tests/rptest/services/verifiable_consumer.py +++ b/tests/rptest/services/verifiable_consumer.py @@ -13,7 +13,7 @@ # See the License for the specific language governing permissions and # limitations under the License. # -# Modifications copyright (C) 2021 Vectorized +# Modifications Copyright 2021 Redpanda Data, Inc. # - Reformatted code # - Replaced dependency on Kafka with Redpanda diff --git a/tests/rptest/services/verifiable_producer.py b/tests/rptest/services/verifiable_producer.py index 89c18f9d145b..96aefb7386c6 100644 --- a/tests/rptest/services/verifiable_producer.py +++ b/tests/rptest/services/verifiable_producer.py @@ -13,7 +13,7 @@ # See the License for the specific language governing permissions and # limitations under the License. # -# Modifications copyright (C) 2021 Vectorized +# Modifications Copyright 2021 Redpanda Data, Inc. # - Reformatted code # - Replaced dependency on Kafka with Redpanda # - Imported a is_int_* helper functions from ducktape test suite diff --git a/tests/rptest/tests/end_to_end.py b/tests/rptest/tests/end_to_end.py index 1b15944b76cb..39561a8b4473 100644 --- a/tests/rptest/tests/end_to_end.py +++ b/tests/rptest/tests/end_to_end.py @@ -13,7 +13,7 @@ # See the License for the specific language governing permissions and # limitations under the License. # -# Modifications copyright (C) 2021 Vectorized +# Modifications Copyright 2021 Redpanda Data, Inc. # - Reformatted code # - Replaced dependency on Kafka with Redpanda # - Imported annotate_missing_msgs helper from kafka test suite diff --git a/tools/redpanda-gdb.py b/tools/redpanda-gdb.py index cda5c071c352..de4de9104017 100644 --- a/tools/redpanda-gdb.py +++ b/tools/redpanda-gdb.py @@ -15,7 +15,7 @@ # along with Scylla. If not, see . # # - Copyright (C) 2015 ScyllaDB -# - 2020 Vectorized - libc++ support and redpanda types +# - Copyright 2020 Redpanda Data, Inc. - libc++ support and redpanda types # # ----- # From 4d84be03770878e63c62018a4b17575151500651 Mon Sep 17 00:00:00 2001 From: Andrew Hsu Date: Mon, 21 Mar 2022 21:58:27 +0000 Subject: [PATCH 5/5] js: update checksum test because CoprocessorTest.ts changed --- src/js/test/utilities/Checksum.test.ts | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/src/js/test/utilities/Checksum.test.ts b/src/js/test/utilities/Checksum.test.ts index 83c1019b7c23..52b36e9a9423 100644 --- a/src/js/test/utilities/Checksum.test.ts +++ b/src/js/test/utilities/Checksum.test.ts @@ -15,7 +15,7 @@ import { join } from "path"; describe("Checksum utilities", () => { describe("When we call getChecksumFromFile", () => { const expectChecksum = - "83e60a8e53690ea88e3970e8edfb703700e0a7e8d566ab9fa19a8598d612917e"; + "d0d8f29527c7226d990eeb26cd44ebcdc8a6311a70a7c68f8f176e61da39d0d0"; describe("Given a existing file", () => { it("Should get file content's checksum", (done) => { const checksumPromise = getChecksumFromFile(