redpanda-data-university / rp-use-cases-algo-trading

7 stars 8 forks source link

Container "---" is not running (Ubuntu 22.04) #1

Closed AssetOverflow closed 1 year ago

AssetOverflow commented 1 year ago

docker compose build

[+] Building 0.9s (7/7) FINISHED => [internal] load build definition from Dockerfile 0.0s => => transferring dockerfile: 399B 0.0s => [internal] load .dockerignore 0.0s => => transferring context: 2B 0.0s => [internal] load metadata for docker.io/library/flink:1.16.0-scala_2.12-java11 0.8s => [auth] library/flink:pull token for registry-1.docker.io 0.0s => [1/2] FROM docker.io/library/flink:1.16.0-scala_2.12-java11@sha256:7cd0583b663bad8aaec86f83324e3489228008af7ecfe47904b56ac566f371ed 0.0s => CACHED [2/2] RUN wget -P /opt/sql-client/lib/ https://repo.maven.apache.org/maven2/org/apache/flink/flink-sql-connector-kafka/1.16.0/flink-sql-connector-kafka-1.16.0.jar; w 0.0s => exporting to image 0.0s => => exporting layers 0.0s => => writing image sha256:399afe783c4708a0d38ac9538f0a23bf3c0c76e04a3881b2369a6dec70967b5c 0.0s => => naming to docker.io/library/rp-use-cases-algo-trading-jobmanager 0.0s [+] Building 0.0s (0/1) [+] Building 0.2s (2/3) => [internal] load build definition from Dockerfile 0.0s => => transferring dockerfile: 399B 0.0s => [internal] load .dockerignore 0.0s => => transferring context: 2B 0.0s [+] Building 0.2s (6/6) FINISHED => [internal] load build definition from Dockerfile 0.0s => => transferring dockerfile: 399B 0.0s => [internal] load .dockerignore 0.0s => => transferring context: 2B 0.0s => [internal] load metadata for docker.io/library/flink:1.16.0-scala_2.12-java11 0.1s [+] Building 0.1s (6/6) FINISHED => [internal] load .dockerignore 0.0s => => transferring context: 2B 0.0s => [internal] load build definition from Dockerfile 0.0s => => transferring dockerfile: 399B 0.0s => [internal] load metadata for docker.io/library/flink:1.16.0-scala_2.12-java11 0.1s => [1/2] FROM docker.io/library/flink:1.16.0-scala_2.12-java11@sha256:7cd0583b663bad8aaec86f83324e3489228008af7ecfe47904b56ac566f371ed 0.0s => CACHED [2/2] RUN wget -P /opt/sql-client/lib/ https://repo.maven.apache.org/maven2/org/apache/flink/flink-sql-connector-kafka/1.16.0/flink-sql-connector-kafka-1.16.0.jar; w 0.0s => exporting to image 0.0s => => exporting layers 0.0s => => writing image sha256:5adf650a3c6007e8d21f17d83fcb05427597ee1d2d7a23f3da3816b302c63b9a 0.0s => => naming to docker.io/library/rp-use-cases-algo-trading-taskmanager


docker compose up -d

[+] Running 5/5 ⠿ Container redpanda-1 Started 0.8s ⠿ Container redpanda-console Started 1.4s ⠿ Container jobmanager Running 0.0s ⠿ Container sql-client Started 0.8s ⠿ Container taskmanager Running


rpk cluster info Error response from daemon: Container 64f078fc8970eae774fdfa8de90c535b98907d61ecd55a6feb51c72da6c45892 is not running

^^^ This is after adding the alias rpk="docker exec -it redpanda-1 rpk" to my ~/.bashrc ^^^

I've done this on my windows pc using docker desktop (windows 11 pro) and my MacBook Pro M1 Pro and it's worked on those OS' so I know I'm doing this right (plus they are simple instructions).

But on my dev server Ubuntu Desktop 22.04 with Docker Engine (stable) installed and everything, it does not work.

AssetOverflow commented 1 year ago

is SSE4.2 required to run RPK, period?

weimeilin79 commented 1 year ago

Can you please dump logs from all containers? That would help us identify the problem faster!

emaxerrno commented 1 year ago

your windows is emulating a very old cpu.

is SSE4.2 required to run RPK, period?

this is an extremely old thing for cpus. i don't have windows but look at the cpu type and try to do pass through on it. you are probably using some virtualization on the CPU

AssetOverflow commented 1 year ago

im using Proxmox on a Dell R710 commercial server with Quad-core or six-core Intel® Xeon® processor 5600 series... should be fine shouldn't it? let me get the dump logs

AssetOverflow commented 1 year ago

@weimeilin79 @emaxerrno

Welcome to the Redpanda community!

Documentation: https://docs.redpanda.com - Product documentation site GitHub Discussion: https://github.com/redpanda-data/redpanda/discussions - Longer, more involved discussions GitHub Issues: https://github.com/redpanda-data/redpanda/issues - Report and track issues with the codebase Support: https://support.redpanda.com - Contact the support team privately Product Feedback: https://redpanda.com/feedback - Let us know how we can improve your experience Slack: https://redpanda.com/slack - Chat about all things Redpanda. Join the conversation! Twitter: https://twitter.com/redpandadata - All the latest Redpanda news!

WARN 2023-03-21 21:09:57,392 [shard 0] seastar - Creation of perf_event based stall detector failed, falling back to posix timer: std::1::system_error (error system:1, perf_event_open() failed: Operation not permitted) INFO 2023-03-21 21:09:57,395 [shard 0] seastar - Created fair group io-queue-0, capacity rate 2147483:2147483, limit 12582912, rate 16777216 (factor 1), threshold 2000 INFO 2023-03-21 21:09:57,395 [shard 0] seastar - IO queue uses 0.75ms latency goal for device 0 INFO 2023-03-21 21:09:57,395 [shard 0] seastar - Created io group dev(0), length limit 4194304:4194304, rate 2147483647:2147483647 INFO 2023-03-21 21:09:57,395 [shard 0] seastar - Created io queue dev(0) capacities: 512:2000:2000 1024:3000:3000 2048:5000:5000 4096:9000:9000 8192:17000:17000 16384:33000:33000 32768:65000:65000 65536:129000:129000 131072:257000:257000 INFO 2023-03-21 21:09:57,396 [shard 0] main - application.cc:299 - Redpanda v22.3.5 - 28b2443c33b0c2f8807bc5c460cc2478cfee1044-dirty INFO 2023-03-21 21:09:57,396 [shard 0] main - application.cc:307 - kernel=5.19.0-35-generic, nodename=64587f746e1e, machine=x86_64 INFO 2023-03-21 21:09:57,396 [shard 0] main - application.cc:235 - System resources: { cpus: 1, available memory: 39.268GiB, reserved memory: 0.000bytes} INFO 2023-03-21 21:09:57,396 [shard 0] main - application.cc:243 - File handle limit: 1048576/1048576 INFO 2023-03-21 21:09:57,398 [shard 0] cluster - config_manager.cc:421 - Can't load config cache: std::1::fs::filesystem::filesystem_error (error system:2, filesystem error: open failed: No such file or directory ["/var/lib/redpanda/data/config_cache.yaml"]) INFO 2023-03-21 21:09:57,399 [shard 0] cluster - config_manager.cc:361 - Can't load config bootstrap file: std::1::__fs::filesystem::filesystem_error (error system:2, filesystem error: open failed: No such file or directory ["/etc/redpanda/.bootstrap.yaml"]) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:551 - Cluster configuration properties: INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:552 - (use rpk cluster config edit to change) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.abort_index_segment_size:50000 - Capacity (in number of txns) of an abort index segment INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.abort_timed_out_transactions_interval_ms:10000 - How often look for the inactive transactions and abort them INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.admin_api_require_auth:0 - Whether admin API clients must provide HTTP Basic authentication headers INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.aggregate_metrics:0 - Enable aggregations of metrics returned by the prometheus '/metrics' endpoint. Metric aggregation is performed by summing the values of samples by labels. Aggregations are performed where it makes sense by the shard and/or partition labels. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.alter_topic_cfg_timeout_ms:5000 - Time to wait for entries replication in controller log when executing alter configuration requst INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.append_chunk_size:16384 - Size of direct write operations to disk in bytes INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.auto_create_topics_enabled:1 - Allow topic auto creation INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_access_key:{nullopt} - AWS access key INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_api_endpoint:{nullopt} - Optional API endpoint INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_api_endpoint_port:443 - TLS port override INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_bucket:{nullopt} - AWS bucket that should be used to store data INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_cache_check_interval:30000 - Timeout to check if cache eviction should be triggered INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_cache_size:21474836480 - Max size of archival cache INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_credentials_source:config_file - The source of credentials to connect to cloud services INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_disable_tls:0 - Disable TLS for all S3 connections INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_enable_compacted_topic_reupload:1 - Enable re-uploading data for compacted topics INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_enable_remote_read:0 - Default remote read config value for new topics INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_enable_remote_write:0 - Default remote write value for new topics INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_enabled:0 - Enable archival storage INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_housekeeping_interval_ms:300000 - Interval for cloud storage housekeeping tasks INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_initial_backoff_ms:100 - Initial backoff time for exponetial backoff algorithm (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_manifest_upload_timeout_ms:10000 - Manifest upload timeout (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_max_connection_idle_time_ms:5000 - Max https connection idle time (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_max_connections:20 - Max number of simultaneous connections to S3 per shard (includes connections used for both uploads and downloads) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_max_materialized_segments_per_shard:{nullopt} - Maximum concurrent readers of remote data per CPU core. If unset, value of topic_partitions_per_shard multiplied by 2 is used. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_max_readers_per_shard:{nullopt} - Maximum concurrent readers of remote data per CPU core. If unset, value of topic_partitions_per_shard is used, i.e. one reader per partition if the shard is at its maximum partition capacity. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_max_segments_pending_deletion_per_partition:5000 - The per-partition limit for the number of segments pending deletion from the cloud. Segments can be deleted due to retention or compaction. If this limit is breached and deletion fails, then segments will be orphaned in the cloud and will have to be removed manually INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_metadata_sync_timeout_ms:10000 - Timeout for SI metadata synchronization INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_readreplica_manifest_sync_timeout_ms:30000 - Timeout to check if new data is available for partition in S3 for read replica INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_reconciliation_interval_ms:1000 - Interval at which the archival service runs reconciliation (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_region:{nullopt} - AWS region that houses the bucket used for storage INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_secret_key:{nullopt} - AWS secret key INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_segment_max_upload_interval_sec:{nullopt} - Time that segment can be kept locally without uploading it to the remote storage (sec) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_segment_upload_timeout_ms:30000 - Log segment upload timeout (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_trust_file:{nullopt} - Path to certificate that should be used to validate server certificate during TLS handshake INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_ctrl_d_coeff:0 - derivative coefficient for upload PID controller. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_ctrl_max_shares:1000 - maximum number of IO and CPU shares that archival upload can use INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_ctrl_min_shares:100 - minimum number of IO and CPU shares that archival upload can use INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_ctrl_p_coeff:-2 - proportional coefficient for upload PID controller INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_ctrl_update_interval_ms:60000 - INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_loop_initial_backoff_ms:100 - Initial backoff interval when there is nothing to upload for a partition (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cloud_storage_upload_loop_max_backoff_ms:10000 - Max backoff interval when there is nothing to upload for a partition (ms) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.cluster_id:{nullopt} - Cluster identifier INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compacted_log_segment_size:268435456 - How large in bytes should each compacted log segment be (default 256MiB) INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_backlog_size:{nullopt} - target backlog size for compaction controller. if not set compaction target compaction backlog would be equal to INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_d_coeff:0.2 - derivative coefficient for compaction PID controller. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_i_coeff:0 - integral coefficient for compaction PID controller. INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_max_shares:1000 - maximum number of IO and CPU shares that compaction process can use INFO 2023-03-21 21:09:57,399 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_min_shares:10 - minimum number of IO and CPU shares that compaction process can use INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_p_coeff:-12.5 - proportional coefficient for compaction PID controller. This has to be negative since compaction backlog should decrease when number of compaction shares increases INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.compaction_ctrl_update_interval_ms:30000 - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_backend_housekeeping_interval_ms:1000 - Interval between iterations of controller backend housekeeping loop INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_log_accummulation_rps_capacity_acls_and_users_operations:{nullopt} - Maximum capacity of rate limit accumulationin controller acls and users operations limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_log_accummulation_rps_capacity_configuration_operations:{nullopt} - Maximum capacity of rate limit accumulationin controller configuration operations limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_log_accummulation_rps_capacity_move_operations:{nullopt} - Maximum capacity of rate limit accumulationin controller move operations limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_log_accummulation_rps_capacity_node_management_operations:{nullopt} - Maximum capacity of rate limit accumulationin controller node management operations limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.controller_log_accummulation_rps_capacity_topic_operations:{nullopt} - Maximum capacity of rate limit accumulationin controller topic operations limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.coproc_max_batch_size:32768 - Maximum amount of bytes to read from one topic read INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.coproc_max_inflight_bytes:10485760 - Maximum amountt of inflight bytes when sending data to wasm engine INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.coproc_max_ingest_bytes:655360 - Maximum amount of data to hold from input logs in memory INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.coproc_offset_flush_interval_ms:300000 - Interval for which all coprocessor offsets are flushed to disk INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.create_topic_timeout_ms:2000 - Timeout (ms) to wait for new topic creation INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.default_num_windows:10 - Default number of quota tracking windows INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.default_topic_partitions:1 - Default number of partitions per topic INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.default_topic_replications:1 - Default replication factor for new topics INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.default_window_sec:1000 - Default quota tracking window size in milliseconds INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.delete_retention_ms:604800000 - delete segments older than this - default 1 week INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.disable_batch_cache:0 - Disable batch cache in log manager INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.disable_metrics:0 - Disable registering metrics exposed on the internal metrics endpoint (/metrics) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.disable_public_metrics:0 - Disable registering metrics exposed on the public metrics endpoint (/public_metrics) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.election_timeout_ms:1500 - Election timeout expressed in milliseconds INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_admin_api: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_auto_rebalance_on_node_add:0 - Enable automatic partition rebalancing when new nodes are added INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_controller_log_rate_limiting:0 - Enables limiting of controller log write rate INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_coproc:0 - Enable coprocessing mode INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_idempotence:1 - Enable idempotent producer INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_leader_balancer:1 - Enable automatic leadership rebalancing INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_metrics_reporter:1 - Enable cluster metrics reporter INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_pid_file:1 - Enable pid file. You probably don't want to change this. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_rack_awareness:0 - Enables rack-aware replica assignment INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_sasl:0 - Enable SASL authentication for Kafka connections, authorization is required. see also kafka_enable_authorization INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.enable_transactions:1 - Enable transactions INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.features_auto_enable:1 - Whether new feature flags may auto-activate after upgrades (true) or must wait for manual activation via the admin API (false) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.fetch_max_bytes:57671680 - Maximum number of bytes returned in fetch request INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.fetch_reads_debounce_timeout:10 - Time to wait for next read in fetch request when requested min bytes wasn't reached INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.fetch_session_eviction_timeout_ms:60000 - Minimum time before which unused session will get evicted from sessions. Maximum time after which inactive session will be deleted is two time given configuration valuecache INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.full_raft_configuration_recovery_pattern:{} - Recover raft configuration on start for NTPs matching pattern INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.group_initial_rebalance_delay:3000 - Extra delay (ms) added to rebalance phase to wait for new members INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.group_max_session_timeout_ms:300000 - The maximum allowed session timeout for registered consumers. Longer timeouts give consumers more time to process messages in between heartbeats at the cost of a longer time to detect failures. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.group_min_session_timeout_ms:6000 - The minimum allowed session timeout for registered consumers. Shorter timeouts result in quicker failure detection at the cost of more frequent consumer heartbeating, which can overwhelm broker resources. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.group_new_member_join_timeout:30000 - Timeout for new member joins INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.group_topic_partitions:3 - Number of partitions in the internal group membership topic INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.health_manager_tick_interval:180000 - How often the health manager runs INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.health_monitor_max_metadata_age:10000 - Max age of metadata cached in the health monitor of non controller node INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.health_monitor_tick_interval:10000 - How often health monitor refresh cluster state INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.id_allocator_batch_size:1000 - Id allocator allocates messages in batches (each batch is a one log record) and then serves requests from memory without touching the log until the batch is exhausted. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.id_allocator_log_capacity:100 - Capacity of the id_allocator log in number of messages. Once it reached id_allocator_stm should compact the log. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.id_allocator_replication: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.internal_topic_replication_factor:3 - Target replication factor for internal topics INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.join_retry_timeout_ms:5000 - Time between cluster join retries in milliseconds INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_admin_topic_api_rate:{nullopt} - Target quota rate (partition mutations per default_window_sec) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_batch_max_bytes:1048576 - Maximum size of a batch processed by server. If batch is compressed the limit applies to compressed batch size INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_connection_rate_limit:{nullopt} - Maximum connections per second for one core INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_connection_rate_limit_overrides:{} - Overrides for specific ips for maximum connections per second for one core INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_connections_max:{nullopt} - Maximum number of Kafka client connections per broker INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_connections_max_overrides:{} - Per-IP overrides of kafka connection count limit, list of : strings INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_connections_max_per_ip:{nullopt} - Maximum number of Kafka client connections from each IP address, per broker INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_enable_authorization:{nullopt} - Enable authorization for Kafka connections. Values:- nil: Ignored. Authorization is enabled with enable_sasl: true; true: authorization is required; false: authorization is disabled. See also: enable_sasl and kafka_api[].authentication_method INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_group_recovery_timeout_ms:30000 - Kafka group recovery timeout expressed in milliseconds INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_max_bytes_per_fetch:67108864 - Limit fetch responses to this many bytes, even if total of partition bytes limits is higher INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_mtls_principal_mapping_rules:{nullopt} - Principal Mapping Rules for mTLS Authentication on the Kafka API INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_depth_alpha:0.8 - Smoothing factor for kafka queue depth control depth tracking. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_depth_update_ms:7000 - Update frequency for kafka queue depth control. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_enable:0 - Enable kafka queue depth control. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_idle_depth:10 - Queue depth when idleness is detected in kafka queue depth control. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_latency_alpha:0.002 - Smoothing parameter for kafka queue depth control latency tracking. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_max_depth:100 - Maximum queue depth used in kafka queue depth control. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_max_latency_ms:80 - Max latency threshold for kafka queue depth control depth tracking. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_min_depth:1 - Minimum queue depth used in kafka queue depth control. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_window_count:12 - Number of windows used in kafka queue depth control latency tracking. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_qdc_window_size_ms:1500 - Window size for kafka queue depth control latency tracking. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_request_max_bytes:104857600 - Maximum size of a single request processed via Kafka API INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_rpc_server_stream_recv_buf:{nullopt} - Userspace receive buffer max size in bytes INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_rpc_server_tcp_recv_buf:{nullopt} - Kafka server TCP receive buffer size in bytes. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kafka_rpc_server_tcp_send_buf:{nullopt} - Kafka server TCP transmit buffer size in bytes. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kvstore_flush_interval:10 - Key-value store flush interval (ms) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.kvstore_max_segment_size:16777216 - Key-value maximum segment size (bytes) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.leader_balancer_idle_timeout:120000 - Leadership rebalancing idle timeout INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.leader_balancer_mute_timeout:300000 - Leadership rebalancing mute timeout INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.leader_balancer_transfer_limit_per_shard:512 - Per shard limit for in progress leadership transfers INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_cleanup_policy:delete - Default topic cleanup policy INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_compaction_interval_ms:10000 - How often do we trigger background compaction INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_compression_type:producer - Default topic compression type INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_message_timestamp_type:CreateTime - Default topic messages timestamp type INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_segment_size:1073741824 - Default log segment size in bytes for topics which do not set segment.bytes INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_segment_size_jitter_percent:5 - Random variation to the segment size limit used for each partition INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_segment_size_max:{nullopt} - Upper bound on topic segment.bytes: higher values will be clamped to this limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.log_segment_size_min:{nullopt} - Lower bound on topic segment.bytes: lower values will be clamped to this limit INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.max_compacted_log_segment_size:5368709120 - Max compacted segment size after consolidation INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.max_concurrent_producer_ids:18446744073709551615 - Max cache size for pids which rm_stm stores inside internal state. In overflow rm_stm will delete old pids and clear their status INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.max_kafka_throttle_delay_ms:60000 - Fail-safe maximum throttle delay on kafka requests INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.max_version: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.members_backend_retry_ms:5000 - Time between members backend reconciliation loop retries INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metadata_dissemination_interval_ms:3000 - Interaval for metadata dissemination batching INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metadata_dissemination_retries:30 - Number of attempts of looking up a topic's meta data like shard before failing a request INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metadata_dissemination_retry_delay_ms:320 - Delay before retry a topic lookup in a shard or other meta tables INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metadata_status_wait_timeout_ms:2000 - Maximum time to wait in metadata request for cluster health to be refreshed INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metrics_reporter_report_interval:86400000 - cluster metrics reporter report interval INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metrics_reporter_tick_interval:60000 - Cluster metrics reporter tick interval INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.metrics_reporter_url:https://m.rp.vectorized.io/v2 - cluster metrics reporter url INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.min_version: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.node_management_operation_timeout_ms:5000 - Timeout for executing node management operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.node_status_interval:100 - Time interval between two node status messages. Node status messages establish liveness status outside of the Raft protocol. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_concurrent_moves:50 - Number of partitions that can be reassigned at once INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_max_disk_usage_percent:80 - Disk usage threshold that triggers moving partitions from the node INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_mode:node_add - Partition autobalancing mode INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_movement_batch_size_bytes:5368709120 - Total size of partitions that autobalancer is going to move in one batch INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_node_availability_timeout_sec:900000 - Node unavailability timeout that triggers moving partitions from the node INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.partition_autobalancing_tick_interval_ms:30000 - Partition autobalancer tick interval INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.quota_manager_gc_sec:30000 - Quota manager GC frequency in milliseconds INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_heartbeat_disconnect_failures:3 - After how many failed heartbeats to forcibly close an unresponsive TCP connection. Set to 0 to disable force disconnection. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_heartbeat_interval_ms:150 - Milliseconds for raft leader heartbeats INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_heartbeat_timeout_ms:3000 - raft heartbeat RPC timeout INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_io_timeout_ms:10000 - Raft I/O timeout INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_learner_recovery_rate:104857600 - Raft learner recovery rate limit in bytes per sec INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_max_concurrent_append_requests_per_follower:16 - Maximum number of concurrent append entries requests sent by leader to one follower INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_max_recovery_memory:{nullopt} - Max memory that can be used for reads in raft recovery process by default 15% of total memory INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_recovery_default_read_size:524288 - default size of read issued during raft follower recovery INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_replicate_batch_window_size:1048576 - Max size of requests cached for replication INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_smp_max_non_local_requests:{nullopt} - Maximum number of x-core requests pending in Raft seastar::smp group. (for more details look at seastar::smp_service_group documentation) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_timeout_now_timeout_ms:1000 - Timeout for a timeout now request INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.raft_transfer_leader_recovery_timeout_ms:10000 - Timeout waiting for follower recovery when transferring leadership INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.readers_cache_eviction_timeout_ms:30000 - Duration after which inactive readers will be evicted from cache INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.reclaim_batch_cache_min_free:67108864 - Free memory limit that will be kept by batch cache background reclaimer INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.reclaim_growth_window:3000 - Length of time in which reclaim sizes grow INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.reclaim_max_size:4194304 - Maximum batch cache reclaim size INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.reclaim_min_size:131072 - Minimum batch cache reclaim size INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.reclaim_stable_window:10000 - Length of time above which growth is reset INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.recovery_append_timeout_ms:5000 - Timeout for append entries requests issued while updating stale follower INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.release_cache_on_segment_roll:0 - Free cache when segments roll INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.replicate_append_timeout_ms:3000 - Timeout for append entries requests issued while replicating entries INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.retention_bytes:{nullopt} - Default max bytes per partition on disk before triggering a compaction INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.retention_local_target_bytes_default:{nullopt} - Local retention size target for partitions of topics with cloud storage write enabled INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.retention_local_target_ms_default:86400000 - Local retention time target for partitions of topics with cloud storage write enabled INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rm_sync_timeout_ms:10000 - Time to wait state catch up before rejecting a request INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rm_violation_recovery_policy:crash - Describes how to recover from an invariant violation happened on the partition level INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rpc_server_listen_backlog:{nullopt} - TCP connection queue length for Kafka server and internal RPC server INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rpc_server_tcp_recv_buf:{nullopt} - Internal RPC TCP receive buffer size in bytes. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rpc_server_tcp_send_buf:{nullopt} - Internal RPC TCP transmit buffer size in bytes. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rps_limit_acls_and_users_operations:1000 - Rate limit for controller acls and users operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rps_limit_configuration_operations:1000 - Rate limit for controller configuration operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rps_limit_move_operations:1000 - Rate limit for controller move operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rps_limit_node_management_operations:1000 - Rate limit for controller node management operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.rps_limit_topic_operations:1000 - Rate limit for controller topic operations INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.seed_server_meta_topic_partitions: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.segment_appender_flush_timeout_ms:1000 - Maximum delay until buffered data is written INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.segment_fallocation_step:33554432 - Size for segments fallocation INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.seq_table_min_size:1000 - Minimum size of the seq table non affected by compaction INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_compaction_index_memory:134217728 - Maximum number of bytes that may be used on each shard by compactionindex writers INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_max_concurrent_replay:1024 - Maximum number of partitions' logs that will be replayed concurrently at startup, or flushed concurrently on shutdown. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_min_free_bytes:10485760 - Threshold of minimum bytes free space before rejecting producers. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_read_buffer_size:131072 - Size of each read buffer (one per in-flight read, per log segment) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_read_readahead_count:10 - How many additional reads to issue ahead of current read location INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_space_alert_free_threshold_bytes:0 - Threshold of minimim bytes free space before setting storage space alert INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_space_alert_free_threshold_percent:5 - Threshold of minimim percent free space before setting storage space alert INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_strict_data_init:0 - Requires that an empty file named .redpanda_data_dir be present in the data directory. Redpanda will refuse to start if it is not found. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.storage_target_replay_bytes:10737418240 - Target bytes to replay from disk on startup after clean shutdown: controls frequency of snapshots and checkpoints INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.superusers:{} - List of superuser usernames INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.target_quota_byte_rate:2147483648 - Target quota byte rate (bytes per second) - 2GB default INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.tm_sync_timeout_ms:10000 - Time to wait state catch up before rejecting a request INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.tm_violation_recovery_policy:crash - Describes how to recover from an invariant violation happened on the transaction coordinator level INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.topic_fds_per_partition:{5} - Required file handles per partition when creating topics INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.topic_memory_per_partition:{1048576} - Required memory per partition when creating topics INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.topic_partitions_per_shard:1000 - Maximum number of partitions which may be allocated to one shard (CPU core) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.topic_partitions_reserve_shard0:2 - Reserved partition slots on shard (CPU core) 0 on each node. If this is >= topic_partitions_per_core, no data partitions will be scheduled on shard 0 INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.transaction_coordinator_cleanup_policy:delete - Cleanup policy for a transaction coordinator topic INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.transaction_coordinator_delete_retention_ms:604800000 - delete segments older than this - default 1 week INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.transaction_coordinator_log_segment_size:1073741824 - How large in bytes should each log segment be (default 1G) INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.transaction_coordinator_replication: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.transactional_id_expiration_ms:604800000 - Producer ids are expired once this time has elapsed after the last write with the given producer id. INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.tx_timeout_delay_ms:1000 - Delay before scheduling next check for timed out transactions INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.use_scheduling_groups: - INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.wait_for_leader_timeout_ms:5000 - Timeout (ms) to wait for leadership in metadata cache INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:527 - redpanda.zstd_decompress_workspace_bytes:8388608 - Size of the zstd decompression workspace INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:555 - Node configuration properties: INFO 2023-03-21 21:09:57,400 [shard 0] main - application.cc:556 - (use rpk redpanda config set <cfg> <value> to change) INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.admin:{{:{host: 0.0.0.0, port: 9644}}} - Address and port of admin server INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.admin_api_doc_dir:/usr/share/redpanda/admin-api-doc - Admin API doc directory INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.admin_api_tls:{} - TLS configuration for admin HTTP server INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.advertised_kafka_api:{{PLAINTEXT:{host: redpanda-1, port: 29092}}, {OUTSIDE:{host: localhost, port: 9092}}} - Address of Kafka API published to the clients INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.advertised_rpc_api:{{host: redpanda-1, port: 33145}} - Address of RPC endpoint published to other cluster members INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.cloud_storage_cache_directory:{nullopt} - Directory for archival cache. Should be present when cloud_storage_enabled is present INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.coproc_supervisor_server:{host: 127.0.0.1, port: 43189} - IpAddress and port for supervisor service INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.dashboard_dir: - INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.data_directory:{data_directory="/var/lib/redpanda/data"} - Place where redpanda will keep the data INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.developer_mode:1 - Skips most of the checks performed at startup, not recomended for production use INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.empty_seed_starts_cluster:1 - If true, an empty seed_servers list will denote that this node should form a cluster. At most one node in the cluster should be configured configured with an empty seed_servers list. If no such configured node exists, or if configured to false, all nodes denoted by the seed_servers list must be identical among those nodes' configurations, and those nodes will form the initial cluster. INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.enable_central_config: - INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.kafka_api:{{PLAINTEXT:{host: 0.0.0.0, port: 29092}:{nullopt}}, {OUTSIDE:{host: 0.0.0.0, port: 9092}:{nullopt}}} - Address and port of an interface to listen for Kafka API requests INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.kafka_api_tls:{} - TLS configuration for Kafka API endpoint INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.node_id:{1} - Unique id identifying a node in the cluster. If missing, a unique id will be assigned for this node when it joins the cluster INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.rack:{nullopt} - Rack identifier INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.rpc_server:{host: 0.0.0.0, port: 33145} - IpAddress and port for RPC server INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.rpc_server_tls:{ enabled: 0 key/cert files: {nullopt} ca file: {nullopt} client_auth_required: 0 } - TLS configuration for RPC server INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - redpanda.seed_servers:{} - List of the seed servers used to join current cluster. If the seed_server list is empty the node will be a cluster root and it will form a new cluster INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.advertised_pandaproxy_api:{{PLAINTEXT:{host: redpanda-1, port: 28082}}, {OUTSIDE:{host: localhost, port: 8082}}} - Rest API address and port to publish to client INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.api_doc_dir:/usr/share/redpanda/proxy-api-doc - API doc directory INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.client_cache_max_size:10 - The maximum number of kafka clients in the LRU cache INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.client_keep_alive:300000 - Time in milliseconds that an idle connection may remain open INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.consumer_instance_timeout_ms:300000 - How long to wait for an idle consumer before removing it INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.pandaproxy_api:{{PLAINTEXT:{host: 0.0.0.0, port: 28082}:}, {OUTSIDE:{host: 0.0.0.0, port: 8082}:}} - Rest API listen address and port INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy.pandaproxy_api_tls:{} - TLS configuration for Pandaproxy api INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.broker_tls:{ enabled: 0 key/cert files: {nullopt} ca file: {nullopt} client_auth_required: 0 } - TLS configuration for the brokers INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.brokers:{{host: 0.0.0.0, port: 29092}} - List of address and port of the brokers INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.client_identifier:{test_client} - Identifier to use within the kafka request header INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.consumer_heartbeat_interval_ms:500 - Interval (in milliseconds) for consumer heartbeats INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.consumer_rebalance_timeout_ms:2000 - Timeout (in milliseconds) for consumer rebalance INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.consumer_request_max_bytes:1048576 - Max bytes to fetch per request INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.consumer_request_timeout_ms:100 - Interval (in milliseconds) for consumer request timeout INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.consumer_session_timeout_ms:300000 - Timeout (in milliseconds) for consumer session INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.produce_batch_delay_ms:100 - Delay (in milliseconds) to wait before sending batch INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.produce_batch_record_count:1000 - Number of records to batch before sending to broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.produce_batch_size_bytes:1048576 - Number of bytes to batch before sending to broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.retries:5 - Number of times to retry a request to a broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.retry_base_backoff_ms:100 - Delay (in milliseconds) for initial retry backoff INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.sasl_mechanism: - The SASL mechanism to use when connecting INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.scram_password: - Password to use for SCRAM authentication mechanisms INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - pandaproxy_client.scram_username: - Username to use for SCRAM authentication mechanisms INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry.api_doc_dir:/usr/share/redpanda/proxy-api-doc - API doc directory INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry.schema_registry_api:{{:{host: 0.0.0.0, port: 8081}:}} - Schema Registry API listen address and port INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry.schema_registry_api_tls:{} - TLS configuration for Schema Registry API INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry.schema_registry_replication_factor:{nullopt} - Replication factor for internal _schemas topic. If unset, defaults to default_topic_replication INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.broker_tls:{ enabled: 0 key/cert files: {nullopt} ca file: {nullopt} client_auth_required: 0 } - TLS configuration for the brokers INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.brokers:{{host: 0.0.0.0, port: 29092}} - List of address and port of the brokers INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.client_identifier:{test_client} - Identifier to use within the kafka request header INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.consumer_heartbeat_interval_ms:500 - Interval (in milliseconds) for consumer heartbeats INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.consumer_rebalance_timeout_ms:2000 - Timeout (in milliseconds) for consumer rebalance INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.consumer_request_max_bytes:1048576 - Max bytes to fetch per request INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.consumer_request_timeout_ms:100 - Interval (in milliseconds) for consumer request timeout INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.consumer_session_timeout_ms:10000 - Timeout (in milliseconds) for consumer session INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.produce_batch_delay_ms:0 - Delay (in milliseconds) to wait before sending batch INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.produce_batch_record_count:0 - Number of records to batch before sending to broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.produce_batch_size_bytes:0 - Number of bytes to batch before sending to broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.retries:5 - Number of times to retry a request to a broker INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.retry_base_backoff_ms:100 - Delay (in milliseconds) for initial retry backoff INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.sasl_mechanism: - The SASL mechanism to use when connecting INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.scram_password: - Password to use for SCRAM authentication mechanisms INFO 2023-03-21 21:09:57,401 [shard 0] main - application.cc:527 - schema_registry_client.scram_username: - Username to use for SCRAM authentication mechanisms INFO 2023-03-21 21:09:57,401 [shard 0] syschecks - Writing pid file "/var/lib/redpanda/data/pid.lock" INFO 2023-03-21 21:09:57,402 [shard 0] main - application.cc:319 - Shutdown complete. ERROR 2023-03-21 21:09:57,402 [shard 0] main - application.cc:333 - Failure during startup: std::runtime_error (sse4.2 support is required to run)

BenPope commented 1 year ago

im using Proxmox on a Dell R710 commercial server with Quad-core or six-core Intel® Xeon® processor 5600 series... should be fine shouldn't it? let me get the dump logs

We build Redpanda for Westmere and the Intel 5600 are Westmere so it should be fine. I've seen this type of error when using virtualisation or emulation with a target CPU that's older than Westmere and can usually be fixed with configuration (I'd usually set target CPU to the same as host unless there are specific requirements otherwise)..

AssetOverflow commented 1 year ago

im using Proxmox on a Dell R710 commercial server with Quad-core or six-core Intel® Xeon® processor 5600 series... should be fine shouldn't it? let me get the dump logs

We build Redpanda for Westmere and the Intel 5600 are Westmere so it should be fine. I've seen this type of error when using virtualisation or emulation with a target CPU that's older than Westmere and can usually be fixed with configuration (I'd usually set target CPU to the same as host unless there are specific requirements otherwise)..

Do you think you could help in providing the specific configurations I would need and where/how I would need to apply them?

BenPope commented 1 year ago

I don't know anything about your configuration.

I found something in the docs, but I can't tell you if it's the cause. I've never used Proxmox and don't know how to configure it.

AssetOverflow commented 1 year ago

no worries.. ty