diff --git a/arc/README.md b/arc/README.md
new file mode 100644
index 000000000..e9e644e03
--- /dev/null
+++ b/arc/README.md
@@ -0,0 +1,175 @@
+# Arc - ClickBench Benchmark
+
+Arc is a high-performance time-series data warehouse built on DuckDB, Parquet, and object storage.
+
+## System Information
+
+- **System:** Arc
+- **Date:** 2025-10-15
+- **Machine:** m3_max (14 cores, 36GB RAM)
+- **Tags:** Python, time-series, DuckDB, Parquet, columnar, HTTP API
+- **License:** AGPL-3.0
+- **Repository:** https://github.com/Basekick-Labs/arc
+
+## Performance
+
+Arc achieves:
+- **Write throughput:** 1.89M records/sec (MessagePack binary protocol)
+- **ClickBench:** ~22 seconds total (43 analytical queries)
+- **Storage:** DuckDB + Parquet with MinIO/S3/GCS backends
+
+## Prerequisites
+
+- Ubuntu/Debian Linux (or compatible)
+- Python 3.11+
+- 8GB+ RAM recommended
+- Internet connection for dataset download
+- Sudo access (only if system dependencies are missing)
+
+## Quick Start
+
+The benchmark script handles everything automatically:
+
+```bash
+./benchmark.sh
+```
+
+This will:
+1. Create Python virtual environment (no system packages modified)
+2. Clone Arc repository
+3. Install dependencies in venv
+4. Start Arc server with optimal worker count (2x CPU cores)
+5. Download ClickBench dataset (14GB parquet file)
+6. Run 43 queries × 3 iterations
+7. Output results in ClickBench JSON format
+
+## Manual Steps
+
+### 1. Install Dependencies
+
+```bash
+sudo apt-get update -y
+sudo apt-get install -y python3-pip python3-venv wget curl
+```
+
+### 2. Create Virtual Environment
+
+```bash
+python3 -m venv arc-venv
+source arc-venv/bin/activate
+```
+
+### 3. Clone and Setup Arc
+
+```bash
+git clone https://github.com/Basekick-Labs/arc.git
+cd arc
+pip install -r requirements.txt
+mkdir -p data logs
+```
+
+### 4. Create API Token
+
+```bash
+python3 << 'EOF'
+from api.auth import AuthManager
+
+auth = AuthManager(db_path='./data/arc.db')
+token = auth.create_token(name='clickbench', description='ClickBench benchmark')
+print(f"Token: {token}")
+EOF
+```
+
+### 5. Start Arc Server
+
+```bash
+# Auto-detect cores
+CORES=$(nproc)
+WORKERS=$((CORES * 2))
+
+# Start server
+gunicorn -w $WORKERS -b 0.0.0.0:8000 \
+ -k uvicorn.workers.UvicornWorker \
+ --timeout 300 \
+ api.main:app
+```
+
+### 6. Download Dataset
+
+```bash
+wget https://datasets.clickhouse.com/hits_compatible/hits.parquet
+```
+
+### 7. Run Benchmark
+
+```bash
+export ARC_URL="http://localhost:8000"
+export ARC_API_KEY="your-token-from-step-4"
+export DATABASE="clickbench"
+export TABLE="hits"
+
+./run.sh
+```
+
+**Note:** The benchmark uses Apache Arrow columnar format for optimal performance. Requires `pyarrow` to be installed.
+
+## Configuration
+
+Arc uses optimal settings for ClickBench (all automatic, no configuration needed):
+
+- **Workers:** Auto-detected cores × 2 (optimal for analytical workloads)
+- **Query cache:** Disabled (per ClickBench rules)
+- **Storage:** Local filesystem (fastest for single-node)
+- **Timeout:** 300 seconds per query
+- **Format:** Apache Arrow (columnar, high-performance)
+
+## Results Format
+
+Results are output in official ClickBench format:
+
+```
+Load time: 0
+Data size: 14779976446
+[0.0226, 0.0233, 0.0284]
+[0.0324, 0.0334, 0.0392]
+...
+```
+
+- **Load time:** Arc queries Parquet files directly without a data loading phase (load time = 0)
+- **Data size:** Size of the dataset in bytes (14GB)
+- **Query results:** 43 lines, each containing 3 execution times (in seconds) for the same query
+
+## Notes
+
+- **Virtual Environment:** All dependencies installed in isolated venv (no `--break-system-packages` needed)
+- **Authentication:** Uses Arc's built-in token auth (simpler than Permission-based auth)
+- **Query Cache:** Disabled to ensure fair benchmark (no cache hits)
+- **Worker Count:** Auto-detected based on CPU cores, optimized for analytical workloads
+- **Timeout:** Generous 300s timeout for complex queries
+
+## Architecture
+
+```
+ClickBench Query → Arc Arrow API → DuckDB → Parquet File → Arrow Results
+```
+
+Arc queries the Parquet file directly via DuckDB's `read_parquet()` function and returns results in Apache Arrow columnar format for maximum efficiency.
+
+## Performance Characteristics
+
+Arc is optimized for:
+- **High-throughput writes** (1.89M RPS with MessagePack)
+- **Analytical queries** (DuckDB's columnar engine)
+- **Columnar data transfer** (Apache Arrow IPC for efficient results)
+- **Object storage** (S3, GCS, MinIO compatibility)
+- **Time-series workloads** (built-in time-based indexing)
+
+## Support
+
+- GitHub: https://github.com/Basekick-Labs/arc
+- Issues: https://github.com/Basekick-Labs/arc/issues
+- Docs: https://docs.arc.basekick.com (coming soon)
+
+## License
+
+Arc Core is licensed under AGPL-3.0.
diff --git a/arc/benchmark.sh b/arc/benchmark.sh
new file mode 100755
index 000000000..55451132e
--- /dev/null
+++ b/arc/benchmark.sh
@@ -0,0 +1,393 @@
+#!/bin/bash
+# Arc ClickBench Complete Benchmark Script
+# This script installs Arc, loads data, and runs the benchmark
+
+set -e
+
+# Check and install system dependencies
+echo "Checking system dependencies..."
+
+MISSING_DEPS=()
+command -v python3 >/dev/null 2>&1 || MISSING_DEPS+=("python3")
+command -v pip3 >/dev/null 2>&1 || MISSING_DEPS+=("python3-pip")
+command -v wget >/dev/null 2>&1 || MISSING_DEPS+=("wget")
+command -v curl >/dev/null 2>&1 || MISSING_DEPS+=("curl")
+
+# Check for python3-venv by detecting Python version
+PYTHON_VERSION=$(python3 --version 2>&1 | awk '{print $2}' | cut -d. -f1,2)
+VENV_PACKAGE="python${PYTHON_VERSION}-venv"
+
+# Try to create a test venv to check if venv is properly installed
+if ! python3 -m venv --help >/dev/null 2>&1 || ! python3 -c "import ensurepip" 2>/dev/null; then
+ MISSING_DEPS+=("$VENV_PACKAGE")
+fi
+
+if [ ${#MISSING_DEPS[@]} -eq 0 ]; then
+ echo "[OK] All system dependencies are already installed"
+else
+ echo "Installing missing dependencies: ${MISSING_DEPS[*]}"
+ sudo apt-get update -y
+ sudo apt-get install -y "${MISSING_DEPS[@]}"
+fi
+
+# Create Python virtual environment
+echo "Creating Python virtual environment..."
+python3 -m venv arc-venv
+source arc-venv/bin/activate
+
+# Clone Arc repository if not exists
+if [ ! -d "arc" ]; then
+ echo "Cloning Arc repository..."
+ git clone https://github.com/Basekick-Labs/arc.git
+fi
+
+cd arc
+
+# Install Arc dependencies in venv
+echo "Installing Arc dependencies..."
+pip install --upgrade pip
+pip install -r requirements.txt
+
+# Create data directory
+mkdir -p data logs
+
+# Create or reuse API token for benchmark
+echo "Setting up API token..."
+python3 << 'EOF'
+from api.auth import AuthManager
+import os
+import time
+
+# Initialize auth manager
+auth = AuthManager(db_path='./data/arc.db')
+
+# Try to create token, or reuse if exists
+token = None
+token_name = f'clickbench-{int(time.time())}'
+
+try:
+ # Try to create new token with timestamp
+ token = auth.create_token(
+ name=token_name,
+ description='ClickBench benchmark access'
+ )
+ print(f"Created new API token: {token_name}")
+except Exception as e:
+ # If that fails, try with a simple name and catch if exists
+ try:
+ token = auth.create_token(
+ name='clickbench',
+ description='ClickBench benchmark access'
+ )
+ print(f"Created API token: clickbench")
+ except ValueError:
+ # Token already exists, list and use existing one
+ print("Token 'clickbench' already exists, retrieving...")
+ tokens = auth.list_tokens()
+ for t in tokens:
+ if t.get('name') == 'clickbench':
+ token = t.get('token')
+ print(f"Reusing existing token: clickbench")
+ break
+
+ if not token:
+ raise Exception("Could not create or retrieve token")
+
+# Write token to file for run.sh to use
+with open('../arc_token.txt', 'w') as f:
+ f.write(token)
+EOF
+
+ARC_TOKEN=$(cat ../arc_token.txt)
+echo "Token ready: $ARC_TOKEN"
+
+# Auto-detect CPU cores (supports Linux and macOS)
+if command -v nproc > /dev/null 2>&1; then
+ # Linux: use nproc
+ CORES=$(nproc)
+elif command -v sysctl > /dev/null 2>&1; then
+ # macOS: use sysctl
+ CORES=$(sysctl -n hw.ncpu 2>/dev/null || sysctl -n hw.logicalcpu 2>/dev/null || echo 4)
+elif [ -f /proc/cpuinfo ]; then
+ # Linux fallback: parse /proc/cpuinfo
+ CORES=$(grep -c processor /proc/cpuinfo)
+else
+ # Final fallback
+ CORES=4
+fi
+
+# Use 2x cores for optimal analytical performance (automatic)
+WORKERS=$((CORES * 2))
+echo "Starting Arc with $WORKERS workers ($CORES cores detected, 2x multiplier for optimal performance)..."
+
+# Create minimal .env if not exists
+if [ ! -f ".env" ]; then
+ cat > .env << 'ENVEOF'
+# Arc Configuration for ClickBench
+STORAGE_BACKEND=local
+LOCAL_STORAGE_PATH=./minio-data
+PORT=8000
+HOST=0.0.0.0
+LOG_LEVEL=WARNING
+QUERY_CACHE_ENABLED=false
+BUFFER_MAX_SIZE=50000
+BUFFER_MAX_AGE=5
+ENVEOF
+fi
+
+# Start Arc server in background
+gunicorn -w $WORKERS -b 0.0.0.0:8000 \
+ -k uvicorn.workers.UvicornWorker \
+ --timeout 300 \
+ --access-logfile /dev/null \
+ --error-logfile ../arc.log \
+ --log-level warning \
+ api.main:app > /dev/null 2>&1 &
+
+ARC_PID=$!
+echo "Arc started with PID: $ARC_PID"
+
+# Wait for Arc to be ready (up to 30 seconds)
+echo "Waiting for Arc to be ready..."
+for i in {1..30}; do
+ if curl -s -f http://localhost:8000/health > /dev/null 2>&1; then
+ echo "[OK] Arc is ready!"
+ break
+ fi
+ if [ $i -eq 30 ]; then
+ echo "Error: Arc failed to start within 30 seconds"
+ echo "Last 50 lines of logs:"
+ tail -50 ../arc.log
+ kill $ARC_PID 2>/dev/null || true
+ exit 1
+ fi
+ sleep 1
+done
+
+cd ..
+
+# Download and prepare dataset
+DATASET_FILE="hits.parquet"
+DATASET_URL="https://datasets.clickhouse.com/hits_compatible/hits.parquet"
+EXPECTED_SIZE=14779976446 # 14GB
+
+if [ -f "$DATASET_FILE" ]; then
+ CURRENT_SIZE=$(stat -f%z "$DATASET_FILE" 2>/dev/null || stat -c%s "$DATASET_FILE" 2>/dev/null)
+ if [ "$CURRENT_SIZE" -eq "$EXPECTED_SIZE" ]; then
+ echo "[OK] Dataset already downloaded (14GB)"
+ else
+ echo "[WARNING] Dataset exists but size mismatch (expected: $EXPECTED_SIZE, got: $CURRENT_SIZE)"
+ echo "Re-downloading dataset..."
+ rm -f "$DATASET_FILE"
+ wget --continue --progress=dot:giga "$DATASET_URL"
+ fi
+else
+ echo "Downloading ClickBench dataset (14GB)..."
+ wget --continue --progress=dot:giga "$DATASET_URL"
+fi
+
+FILE_SIZE=$(du -h "$DATASET_FILE" | cut -f1)
+echo "Dataset size: $FILE_SIZE ($DATASET_FILE)"
+
+# Count rows using DuckDB
+echo "Counting rows..."
+python3 << 'EOF'
+import duckdb
+conn = duckdb.connect()
+count = conn.execute("SELECT COUNT(*) FROM read_parquet('hits.parquet')").fetchone()[0]
+print(f"Dataset contains {count:,} rows")
+EOF
+
+# Set environment variables for benchmarking
+export ARC_URL="http://localhost:8000"
+export ARC_API_KEY="$ARC_TOKEN"
+export DATABASE="clickbench"
+export TABLE="hits"
+
+# Load data into Arc by copying parquet file to storage
+echo ""
+echo "Loading ClickBench data into Arc..."
+echo "================================================"
+
+STORAGE_BASE="arc/data/arc"
+TARGET_DIR="$STORAGE_BASE/$DATABASE/$TABLE"
+TARGET_FILE="$TARGET_DIR/hits.parquet"
+
+# Create target directory
+mkdir -p "$TARGET_DIR"
+
+# Check if already loaded
+if [ -f "$TARGET_FILE" ]; then
+ SOURCE_SIZE=$(stat -f%z "$DATASET_FILE" 2>/dev/null || stat -c%s "$DATASET_FILE" 2>/dev/null)
+ TARGET_SIZE=$(stat -f%z "$TARGET_FILE" 2>/dev/null || stat -c%s "$TARGET_FILE" 2>/dev/null)
+
+ if [ "$SOURCE_SIZE" -eq "$TARGET_SIZE" ]; then
+ echo "[OK] Data already loaded (14GB)"
+ echo " Location: $TARGET_FILE"
+ else
+ echo "[WARNING] Existing file has different size, reloading..."
+ rm -f "$TARGET_FILE"
+ echo " Copying parquet file to Arc storage..."
+ cp "$DATASET_FILE" "$TARGET_FILE"
+ echo "[OK] Data loaded successfully!"
+ fi
+else
+ echo " Copying parquet file to Arc storage..."
+ echo " Source: $DATASET_FILE"
+ echo " Target: $TARGET_FILE"
+ cp "$DATASET_FILE" "$TARGET_FILE"
+ echo "[OK] Data loaded successfully!"
+ echo " Table: $DATABASE.$TABLE"
+ TARGET_SIZE=$(du -h "$TARGET_FILE" | cut -f1)
+ echo " Size: $TARGET_SIZE"
+fi
+
+echo ""
+echo "Data loading complete."
+
+# Verify query cache configuration
+echo ""
+echo "Verifying query cache configuration..."
+cd arc
+python3 << 'CACHECHECK'
+import os
+import sys
+
+# Check all possible cache configuration sources
+print("=" * 70)
+print("Query Cache Configuration Check")
+print("=" * 70)
+
+# 1. Check arc.conf
+cache_in_conf = None
+try:
+ from config_loader import get_config
+ arc_config = get_config()
+ cache_config = arc_config.config.get('query_cache', {})
+ cache_in_conf = cache_config.get('enabled', None)
+ print(f" arc.conf: enabled = {cache_in_conf}")
+except Exception as e:
+ print(f" arc.conf: Error reading: {e}")
+
+# 2. Check .env file
+cache_in_env = None
+if os.path.exists('.env'):
+ with open('.env', 'r') as f:
+ for line in f:
+ if line.strip().startswith('QUERY_CACHE_ENABLED'):
+ cache_in_env = line.split('=')[1].strip().lower()
+ print(f" .env: QUERY_CACHE_ENABLED = {cache_in_env}")
+ break
+ if cache_in_env is None:
+ print(f" .env: QUERY_CACHE_ENABLED not set")
+else:
+ print(f" .env: File not found")
+
+# 3. Check environment variable
+cache_in_os_env = os.getenv("QUERY_CACHE_ENABLED")
+if cache_in_os_env:
+ print(f" Environment: QUERY_CACHE_ENABLED = {cache_in_os_env}")
+else:
+ print(f" Environment: QUERY_CACHE_ENABLED not set")
+
+# 4. Check what init_query_cache will actually use
+print("")
+try:
+ from api.query_cache import init_query_cache
+ cache_instance = init_query_cache()
+ if cache_instance is None:
+ print(f"[OK] FINAL RESULT: Query cache is DISABLED")
+ else:
+ print(f"[ERROR] FINAL RESULT: Query cache is ENABLED")
+ print(f" TTL: {cache_instance.ttl_seconds}s")
+ print(f" Max size: {cache_instance.max_size}")
+ print(f"\n [WARNING] Cache must be disabled for valid benchmark results!")
+except Exception as e:
+ print(f"[ERROR] Error checking cache initialization: {e}")
+
+print("=" * 70)
+CACHECHECK
+
+cd ..
+
+# Test API token before running benchmark
+echo ""
+echo "Testing API token authentication..."
+TEST_RESPONSE=$(curl -s -w "\n%{http_code}" -H "x-api-key: $ARC_API_KEY" "$ARC_URL/health")
+HTTP_CODE=$(echo "$TEST_RESPONSE" | tail -n1)
+if [ "$HTTP_CODE" = "200" ]; then
+ echo "[OK] API token is valid"
+else
+ echo "[ERROR] API token test failed (HTTP $HTTP_CODE)"
+ echo "Response: $(echo "$TEST_RESPONSE" | head -n-1)"
+ echo ""
+ echo "Debugging: Let's verify the token exists in the database..."
+ cd arc
+ python3 << 'DEBUGEOF'
+from api.auth import AuthManager
+auth = AuthManager(db_path='./data/arc.db')
+tokens = auth.list_tokens()
+print(f"Found {len(tokens)} tokens in database:")
+for t in tokens:
+ print(f" - {t.get('name')}: {t.get('token')[:20]}...")
+DEBUGEOF
+ cd ..
+ echo ""
+ echo "Error: Cannot proceed without valid authentication"
+ kill $ARC_PID 2>/dev/null || true
+ exit 1
+fi
+
+# Run benchmark
+echo ""
+echo "Running ClickBench queries via Arc Arrow API..."
+echo "================================================"
+echo "(Logging to log.txt, this may take a few minutes...)"
+./run.sh > log.txt 2>&1
+echo "Benchmark execution complete!"
+
+# Stop Arc
+echo ""
+echo "Stopping Arc..."
+kill $ARC_PID 2>/dev/null || true
+wait $ARC_PID 2>/dev/null || true
+
+# Deactivate venv
+deactivate
+
+# Format results for ClickBench (official format)
+echo ""
+echo "Formatting results..."
+
+# Extract timing values from log
+cat log.txt | grep -oE '^[0-9]+\.[0-9]+|^null' | \
+ awk '{
+ if (NR % 3 == 1) printf "[";
+ printf "%s", $1;
+ if (NR % 3 == 0) print "]";
+ else printf ", ";
+ }' > results.txt
+
+# Output in official ClickBench format
+echo ""
+echo "[OK] Benchmark complete!"
+echo ""
+echo "================================================"
+echo "Official ClickBench Results"
+echo "================================================"
+echo ""
+
+# Load time (Arc doesn't load data, it queries Parquet directly)
+echo "Load time: 0"
+
+# Data size in bytes
+echo "Data size: $EXPECTED_SIZE"
+
+# Query results (43 lines)
+cat results.txt
+
+echo ""
+echo "================================================"
+echo "Results saved to: results.txt"
+echo "Full logs saved to: log.txt"
+echo "================================================"
diff --git a/arc/create.sql b/arc/create.sql
new file mode 100644
index 000000000..9c5f4857a
--- /dev/null
+++ b/arc/create.sql
@@ -0,0 +1,116 @@
+-- Arc ClickBench Schema
+--
+-- Note: Arc queries Parquet files directly via DuckDB, so no explicit table creation is needed.
+-- The benchmark.sh script copies the hits.parquet file to Arc's storage directory:
+-- arc/data/arc/clickbench/hits/hits.parquet
+--
+-- Arc automatically detects and queries Parquet files without requiring schema definition.
+-- This file documents the equivalent schema for reference.
+
+CREATE TABLE hits (
+ WatchID BIGINT,
+ JavaEnable SMALLINT,
+ Title VARCHAR,
+ GoodEvent SMALLINT,
+ EventTime BIGINT,
+ EventDate USMALLINT,
+ CounterID INTEGER,
+ ClientIP INTEGER,
+ RegionID INTEGER,
+ UserID BIGINT,
+ CounterClass SMALLINT,
+ OS SMALLINT,
+ UserAgent SMALLINT,
+ URL VARCHAR,
+ Referer VARCHAR,
+ IsRefresh SMALLINT,
+ RefererCategoryID SMALLINT,
+ RefererRegionID INTEGER,
+ URLCategoryID SMALLINT,
+ URLRegionID INTEGER,
+ ResolutionWidth SMALLINT,
+ ResolutionHeight SMALLINT,
+ ResolutionDepth SMALLINT,
+ FlashMajor SMALLINT,
+ FlashMinor SMALLINT,
+ FlashMinor2 VARCHAR,
+ NetMajor SMALLINT,
+ NetMinor SMALLINT,
+ UserAgentMajor SMALLINT,
+ UserAgentMinor VARCHAR,
+ CookieEnable SMALLINT,
+ JavascriptEnable SMALLINT,
+ IsMobile SMALLINT,
+ MobilePhone SMALLINT,
+ MobilePhoneModel VARCHAR,
+ Params VARCHAR,
+ IPNetworkID INTEGER,
+ TraficSourceID SMALLINT,
+ SearchEngineID SMALLINT,
+ SearchPhrase VARCHAR,
+ AdvEngineID SMALLINT,
+ IsArtifical SMALLINT,
+ WindowClientWidth SMALLINT,
+ WindowClientHeight SMALLINT,
+ ClientTimeZone SMALLINT,
+ ClientEventTime BIGINT,
+ SilverlightVersion1 SMALLINT,
+ SilverlightVersion2 SMALLINT,
+ SilverlightVersion3 INTEGER,
+ SilverlightVersion4 SMALLINT,
+ PageCharset VARCHAR,
+ CodeVersion INTEGER,
+ IsLink SMALLINT,
+ IsDownload SMALLINT,
+ IsNotBounce SMALLINT,
+ FUniqID BIGINT,
+ OriginalURL VARCHAR,
+ HID INTEGER,
+ IsOldCounter SMALLINT,
+ IsEvent SMALLINT,
+ IsParameter SMALLINT,
+ DontCountHits SMALLINT,
+ WithHash SMALLINT,
+ HitColor VARCHAR,
+ LocalEventTime BIGINT,
+ Age SMALLINT,
+ Sex SMALLINT,
+ Income SMALLINT,
+ Interests SMALLINT,
+ Robotness SMALLINT,
+ RemoteIP INTEGER,
+ WindowName INTEGER,
+ OpenerName INTEGER,
+ HistoryLength SMALLINT,
+ BrowserLanguage VARCHAR,
+ BrowserCountry VARCHAR,
+ SocialNetwork VARCHAR,
+ SocialAction VARCHAR,
+ HTTPError SMALLINT,
+ SendTiming INTEGER,
+ DNSTiming INTEGER,
+ ConnectTiming INTEGER,
+ ResponseStartTiming INTEGER,
+ ResponseEndTiming INTEGER,
+ FetchTiming INTEGER,
+ SocialSourceNetworkID SMALLINT,
+ SocialSourcePage VARCHAR,
+ ParamPrice BIGINT,
+ ParamOrderID VARCHAR,
+ ParamCurrency VARCHAR,
+ ParamCurrencyID SMALLINT,
+ OpenstatServiceName VARCHAR,
+ OpenstatCampaignID VARCHAR,
+ OpenstatAdID VARCHAR,
+ OpenstatSourceID VARCHAR,
+ UTMSource VARCHAR,
+ UTMMedium VARCHAR,
+ UTMCampaign VARCHAR,
+ UTMContent VARCHAR,
+ UTMTerm VARCHAR,
+ FromTag VARCHAR,
+ HasGCLID SMALLINT,
+ RefererHash BIGINT,
+ URLHash BIGINT,
+ CLID INTEGER
+);
diff --git a/arc/queries.sql b/arc/queries.sql
new file mode 100644
index 000000000..64b056b91
--- /dev/null
+++ b/arc/queries.sql
@@ -0,0 +1,47 @@
+-- ClickBench Queries for Arc
+-- Original: https://github.com/ClickHouse/ClickBench
+-- Adapted for Arc's DuckDB engine (table name: clickbench.hits)
+
+SELECT COUNT(*) FROM clickbench.hits;
+SELECT COUNT(*) FROM clickbench.hits WHERE AdvEngineID <> 0;
+SELECT SUM(AdvEngineID), COUNT(*), AVG(ResolutionWidth) FROM clickbench.hits;
+SELECT AVG(UserID) FROM clickbench.hits;
+SELECT COUNT(DISTINCT UserID) FROM clickbench.hits;
+SELECT COUNT(DISTINCT SearchPhrase) FROM clickbench.hits;
+SELECT MIN(EventDate), MAX(EventDate) FROM clickbench.hits;
+SELECT AdvEngineID, COUNT(*) FROM clickbench.hits WHERE AdvEngineID <> 0 GROUP BY AdvEngineID ORDER BY COUNT(*) DESC;
+SELECT RegionID, COUNT(DISTINCT UserID) AS u FROM clickbench.hits GROUP BY RegionID ORDER BY u DESC LIMIT 10;
+SELECT RegionID, SUM(AdvEngineID), COUNT(*) AS c, AVG(ResolutionWidth), COUNT(DISTINCT UserID) FROM clickbench.hits GROUP BY RegionID ORDER BY c DESC LIMIT 10;
+SELECT MobilePhoneModel, COUNT(DISTINCT UserID) AS u FROM clickbench.hits WHERE MobilePhoneModel <> '' GROUP BY MobilePhoneModel ORDER BY u DESC LIMIT 10;
+SELECT MobilePhone, MobilePhoneModel, COUNT(DISTINCT UserID) AS u FROM clickbench.hits WHERE MobilePhoneModel <> '' GROUP BY MobilePhone, MobilePhoneModel ORDER BY u DESC LIMIT 10;
+SELECT SearchPhrase, COUNT(*) AS c FROM clickbench.hits WHERE SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT SearchPhrase, COUNT(DISTINCT UserID) AS u FROM clickbench.hits WHERE SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY u DESC LIMIT 10;
+SELECT SearchEngineID, SearchPhrase, COUNT(*) AS c FROM clickbench.hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT UserID, COUNT(*) FROM clickbench.hits GROUP BY UserID ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID, SearchPhrase, COUNT(*) FROM clickbench.hits GROUP BY UserID, SearchPhrase ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID, SearchPhrase, COUNT(*) FROM clickbench.hits GROUP BY UserID, SearchPhrase LIMIT 10;
+SELECT UserID, minute(to_timestamp(EventTime)) AS m, SearchPhrase, COUNT(*) FROM clickbench.hits GROUP BY UserID, m, SearchPhrase ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID FROM clickbench.hits WHERE UserID = 435090932899640449;
+SELECT COUNT(*) FROM clickbench.hits WHERE URL LIKE '%google%';
+SELECT SearchPhrase, MIN(URL), COUNT(*) AS c FROM clickbench.hits WHERE URL LIKE '%google%' AND SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT SearchPhrase, MIN(URL), MIN(Title), COUNT(*) AS c, COUNT(DISTINCT UserID) FROM clickbench.hits WHERE Title LIKE '%Google%' AND URL NOT LIKE '%.google.%' AND SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT * FROM clickbench.hits WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10;
+SELECT SearchPhrase FROM clickbench.hits WHERE SearchPhrase <> '' ORDER BY EventTime LIMIT 10;
+SELECT SearchPhrase FROM clickbench.hits WHERE SearchPhrase <> '' ORDER BY SearchPhrase LIMIT 10;
+SELECT SearchPhrase FROM clickbench.hits WHERE SearchPhrase <> '' ORDER BY EventTime, SearchPhrase LIMIT 10;
+SELECT CounterID, AVG(length(URL)) AS l, COUNT(*) AS c FROM clickbench.hits WHERE URL <> '' GROUP BY CounterID HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '\1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM clickbench.hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT SUM(ResolutionWidth), SUM(ResolutionWidth + 1), SUM(ResolutionWidth + 2), SUM(ResolutionWidth + 3), SUM(ResolutionWidth + 4), SUM(ResolutionWidth + 5), SUM(ResolutionWidth + 6), SUM(ResolutionWidth + 7), SUM(ResolutionWidth + 8), SUM(ResolutionWidth + 9), SUM(ResolutionWidth + 10), SUM(ResolutionWidth + 11), SUM(ResolutionWidth + 12), SUM(ResolutionWidth + 13), SUM(ResolutionWidth + 14), SUM(ResolutionWidth + 15), SUM(ResolutionWidth + 16), SUM(ResolutionWidth + 17), SUM(ResolutionWidth + 18), SUM(ResolutionWidth + 19), SUM(ResolutionWidth + 20), SUM(ResolutionWidth + 21), SUM(ResolutionWidth + 22), SUM(ResolutionWidth + 23), SUM(ResolutionWidth + 24), SUM(ResolutionWidth + 25), SUM(ResolutionWidth + 26), SUM(ResolutionWidth + 27), SUM(ResolutionWidth + 28), SUM(ResolutionWidth + 29), SUM(ResolutionWidth + 30), SUM(ResolutionWidth + 31), SUM(ResolutionWidth + 32), SUM(ResolutionWidth + 33), SUM(ResolutionWidth + 34), SUM(ResolutionWidth + 35), SUM(ResolutionWidth + 36), SUM(ResolutionWidth + 37), SUM(ResolutionWidth + 38), SUM(ResolutionWidth + 39), SUM(ResolutionWidth + 40), SUM(ResolutionWidth + 41), SUM(ResolutionWidth + 42), SUM(ResolutionWidth + 43), SUM(ResolutionWidth + 44), SUM(ResolutionWidth + 45), SUM(ResolutionWidth + 46), SUM(ResolutionWidth + 47), SUM(ResolutionWidth + 48), SUM(ResolutionWidth + 49), SUM(ResolutionWidth + 50), SUM(ResolutionWidth + 51), SUM(ResolutionWidth + 52), SUM(ResolutionWidth + 53), SUM(ResolutionWidth + 54), SUM(ResolutionWidth + 55), SUM(ResolutionWidth + 56), SUM(ResolutionWidth + 57), SUM(ResolutionWidth + 58), SUM(ResolutionWidth + 59), SUM(ResolutionWidth + 60), SUM(ResolutionWidth + 61), SUM(ResolutionWidth + 62), SUM(ResolutionWidth + 63), SUM(ResolutionWidth + 64), SUM(ResolutionWidth + 65), SUM(ResolutionWidth + 66), SUM(ResolutionWidth + 67), SUM(ResolutionWidth + 68), SUM(ResolutionWidth + 69), SUM(ResolutionWidth + 70), SUM(ResolutionWidth + 71), SUM(ResolutionWidth + 72), SUM(ResolutionWidth + 73), SUM(ResolutionWidth + 74), SUM(ResolutionWidth + 75), SUM(ResolutionWidth + 76), SUM(ResolutionWidth + 77), SUM(ResolutionWidth + 78), SUM(ResolutionWidth + 79), SUM(ResolutionWidth + 80), SUM(ResolutionWidth + 81), SUM(ResolutionWidth + 82), SUM(ResolutionWidth + 83), SUM(ResolutionWidth + 84), SUM(ResolutionWidth + 85), SUM(ResolutionWidth + 86), SUM(ResolutionWidth + 87), SUM(ResolutionWidth + 88), SUM(ResolutionWidth + 89) FROM clickbench.hits;
+SELECT SearchEngineID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM clickbench.hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM clickbench.hits WHERE SearchPhrase <> '' GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM clickbench.hits GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT URL, COUNT(*) AS c FROM clickbench.hits GROUP BY URL ORDER BY c DESC LIMIT 10;
+SELECT 1, URL, COUNT(*) AS c FROM clickbench.hits GROUP BY 1, URL ORDER BY c DESC LIMIT 10;
+SELECT ClientIP, ClientIP - 1, ClientIP - 2, ClientIP - 3, COUNT(*) AS c FROM clickbench.hits GROUP BY ClientIP, ClientIP - 1, ClientIP - 2, ClientIP - 3 ORDER BY c DESC LIMIT 10;
+SELECT URL, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND DontCountHits = 0 AND IsRefresh = 0 AND URL <> '' GROUP BY URL ORDER BY PageViews DESC LIMIT 10;
+SELECT Title, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND DontCountHits = 0 AND IsRefresh = 0 AND Title <> '' GROUP BY Title ORDER BY PageViews DESC LIMIT 10;
+SELECT URL, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND IsRefresh = 0 AND IsLink <> 0 AND IsDownload = 0 GROUP BY URL ORDER BY PageViews DESC LIMIT 10 OFFSET 1000;
+SELECT TraficSourceID, SearchEngineID, AdvEngineID, CASE WHEN (SearchEngineID = 0 AND AdvEngineID = 0) THEN Referer ELSE '' END AS Src, URL AS Dst, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND IsRefresh = 0 GROUP BY TraficSourceID, SearchEngineID, AdvEngineID, Src, Dst ORDER BY PageViews DESC LIMIT 10 OFFSET 1000;
+SELECT URLHash, EventDate, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND IsRefresh = 0 AND TraficSourceID IN (-1, 6) AND RefererHash = 3594120000172545465 GROUP BY URLHash, EventDate ORDER BY PageViews DESC LIMIT 10 OFFSET 100;
+SELECT WindowClientWidth, WindowClientHeight, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15887 AND EventDate <= 15917 AND IsRefresh = 0 AND DontCountHits = 0 AND URLHash = 2868770270353813622 GROUP BY WindowClientWidth, WindowClientHeight ORDER BY PageViews DESC LIMIT 10 OFFSET 10000;
+SELECT DATE_TRUNC('minute', to_timestamp(EventTime)) AS M, COUNT(*) AS PageViews FROM clickbench.hits WHERE CounterID = 62 AND EventDate >= 15900 AND EventDate <= 15901 AND IsRefresh = 0 AND DontCountHits = 0 GROUP BY DATE_TRUNC('minute', to_timestamp(EventTime)) ORDER BY DATE_TRUNC('minute', to_timestamp(EventTime)) LIMIT 10 OFFSET 1000;
diff --git a/arc/results/c6a.2xlarge.json b/arc/results/c6a.2xlarge.json
new file mode 100644
index 000000000..3fa5ffbbc
--- /dev/null
+++ b/arc/results/c6a.2xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c6a.2xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.136, 0.096, 0.074],
+ [0.127, 0.112, 0.111],
+ [0.181, 0.151, 0.177],
+ [0.223, 0.151, 0.144],
+ [0.589, 0.562, 0.562],
+ [1.029, 0.928, 0.943],
+ [0.243, 0.133, 0.145],
+ [0.23, 0.133, 0.129],
+ [1.254, 0.778, 0.732],
+ [0.951, 0.931, 0.944],
+ [0.297, 0.282, 0.299],
+ [0.331, 0.346, 0.32],
+ [0.945, 0.912, 0.901],
+ [1.352, 1.338, 1.325],
+ [1.027, 1.006, 0.976],
+ [0.625, 0.636, 0.636],
+ [1.72, 1.688, 1.691],
+ [1.338, 1.326, 1.405],
+ [6.22, 6.124, 6.129],
+ [0.099, 0.162, 0.099],
+ [8.68, 1.757, 1.758],
+ [1.608, 1.6, 1.598],
+ [7.857, 3.193, 3.232],
+ [0.892, 0.783, 0.762],
+ [0.293, 0.302, 0.306],
+ [0.578, 0.565, 0.57],
+ [0.25, 0.25, 0.25],
+ [1.926, 1.925, 1.916],
+ [17.739, 17.519, 17.484],
+ [0.157, 0.151, 0.246],
+ [1.29, 1.065, 1.058],
+ [2.691, 1.231, 1.206],
+ [3.488, 4.231, 3.888],
+ [3.697, 3.675, 3.615],
+ [3.713, 3.683, 3.755],
+ [1.268, 1.024, 0.974],
+ [0.201, 0.197, 0.224],
+ [0.223, 0.196, 0.19],
+ [0.146, 0.148, 0.155],
+ [0.367, 0.318, 0.305],
+ [0.129, 0.148, 0.116],
+ [0.117, 0.12, 0.118],
+ [0.29, 0.282, 0.269]
+]
+}
+
diff --git a/arc/results/c6a.4xlarge.json b/arc/results/c6a.4xlarge.json
new file mode 100644
index 000000000..931a9e4da
--- /dev/null
+++ b/arc/results/c6a.4xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c6a.4xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.349, 0.098, 0.072],
+ [0.206, 0.085, 0.09],
+ [0.143, 0.108, 0.111],
+ [0.115, 0.119, 0.126],
+ [0.434, 0.372, 0.374],
+ [0.614, 0.576, 0.57],
+ [0.152, 0.098, 0.093],
+ [0.16, 0.101, 0.104],
+ [0.514, 0.487, 0.489],
+ [0.607, 0.587, 0.588],
+ [0.178, 0.174, 0.19],
+ [0.205, 0.209, 0.213],
+ [0.612, 0.59, 0.581],
+ [0.946, 0.915, 0.907],
+ [0.618, 0.635, 0.638],
+ [0.503, 0.464, 0.46],
+ [1.124, 1.047, 1.032],
+ [0.804, 0.908, 0.851],
+ [3.389, 3.337, 3.387],
+ [0.096, 0.099, 0.097],
+ [1.06, 0.951, 0.949],
+ [0.872, 0.882, 0.873],
+ [1.692, 1.717, 1.702],
+ [0.532, 0.551, 0.562],
+ [0.225, 0.231, 0.234],
+ [0.339, 0.33, 0.327],
+ [0.177, 0.168, 0.176],
+ [1.033, 1.035, 1.03],
+ [9.031, 9.109, 9.118],
+ [0.118, 0.112, 0.113],
+ [0.965, 0.631, 0.615],
+ [0.728, 0.726, 0.752],
+ [2.114, 1.981, 1.969],
+ [2.349, 2.352, 2.355],
+ [2.422, 2.382, 2.417],
+ [0.626, 0.819, 0.578],
+ [0.175, 0.2, 0.192],
+ [0.16, 0.164, 0.172],
+ [0.149, 0.142, 0.147],
+ [0.339, 0.309, 0.311],
+ [0.103, 0.108, 0.098],
+ [0.095, 0.1, 0.093],
+ [0.256, 0.266, 0.257]
+]
+}
+
diff --git a/arc/results/c6a.metal.json b/arc/results/c6a.metal.json
new file mode 100644
index 000000000..3668ba67b
--- /dev/null
+++ b/arc/results/c6a.metal.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c6a.metal",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.131, 0.072, 0.073],
+ [0.14, 0.146, 0.117],
+ [0.118, 0.14, 0.11],
+ [0.113, 0.148, 0.123],
+ [0.383, 0.543, 0.501],
+ [0.448, 0.437, 0.32],
+ [0.1, 0.095, 0.099],
+ [0.136, 0.113, 0.129],
+ [0.242, 0.459, 0.387],
+ [0.662, 0.351, 0.35],
+ [0.146, 0.14, 0.158],
+ [0.141, 0.155, 0.149],
+ [0.469, 0.278, 0.308],
+ [0.561, 0.385, 0.63],
+ [0.331, 0.329, 0.533],
+ [0.587, 0.474, 0.627],
+ [0.787, 0.932, 0.409],
+ [0.614, 0.583, 0.754],
+ [0.84, 1.072, 1.384],
+ [0.19, 0.111, 0.122],
+ [0.29, 0.292, 0.306],
+ [0.27, 0.336, 0.294],
+ [0.556, 0.47, 0.481],
+ [0.606, 0.82, 0.504],
+ [0.245, 0.273, 0.23],
+ [0.161, 0.181, 0.194],
+ [0.162, 0.171, 0.158],
+ [0.348, 0.344, 0.55],
+ [2.828, 3.088, 4.168],
+ [0.296, 0.288, 0.293],
+ [0.383, 0.686, 0.258],
+ [0.326, 0.422, 1.264],
+ [1.532, 1.343, 1.475],
+ [0.886, 1.171, 1.252],
+ [0.749, 0.771, 1.104],
+ [0.333, 0.832, 0.429],
+ [0.344, 0.361, 0.261],
+ [0.273, 0.259, 0.273],
+ [0.317, 0.251, 0.231],
+ [0.304, 0.312, 0.312],
+ [0.101, 0.11, 0.125],
+ [0.126, 0.131, 0.125],
+ [0.272, 0.304, 0.331]
+]
+}
+
diff --git a/arc/results/c7a.metal-48xl.json b/arc/results/c7a.metal-48xl.json
new file mode 100644
index 000000000..cffad76ea
--- /dev/null
+++ b/arc/results/c7a.metal-48xl.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c7a.metal-48xl",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.137, 0.079, 0.134],
+ [0.124, 0.111, 0.127],
+ [0.108, 0.116, 0.124],
+ [0.155, 0.131, 0.12],
+ [0.581, 0.437, 0.466],
+ [0.455, 0.426, 0.258],
+ [0.116, 0.132, 0.092],
+ [0.09, 0.089, 0.089],
+ [0.419, 0.602, 0.527],
+ [0.683, 0.73, 0.591],
+ [0.124, 0.129, 0.137],
+ [0.133, 0.131, 0.131],
+ [0.329, 0.261, 0.236],
+ [0.352, 0.818, 0.585],
+ [0.597, 0.721, 0.657],
+ [0.295, 0.306, 0.322],
+ [0.608, 0.632, 0.521],
+ [0.6, 0.686, 0.704],
+ [0.955, 0.849, 0.958],
+ [0.138, 0.094, 0.103],
+ [0.278, 0.268, 0.258],
+ [0.227, 0.244, 0.458],
+ [0.945, 0.366, 0.346],
+ [0.547, 0.508, 0.467],
+ [0.2, 0.203, 0.204],
+ [0.17, 0.155, 0.296],
+ [0.136, 0.147, 0.18],
+ [0.58, 0.29, 0.279],
+ [2.904, 2.706, 3.408],
+ [0.133, 0.126, 0.104],
+ [0.768, 0.612, 0.672],
+ [1.023, 0.945, 1.163],
+ [1.301, 1.34, 1.128],
+ [1.418, 1.362, 1.294],
+ [1.205, 1.156, 1.111],
+ [0.171, 0.188, 0.688],
+ [0.174, 0.188, 0.185],
+ [0.161, 0.16, 0.149],
+ [0.126, 0.131, 0.128],
+ [0.284, 0.304, 0.289],
+ [0.096, 0.122, 0.138],
+ [0.123, 0.112, 0.116],
+ [0.242, 0.252, 0.236]
+]
+}
+
diff --git a/arc/results/c8g.4xlarge.json b/arc/results/c8g.4xlarge.json
new file mode 100644
index 000000000..2f5b031ac
--- /dev/null
+++ b/arc/results/c8g.4xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c8g.4xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.536, 0.089, 0.087],
+ [0.138, 0.081, 0.08],
+ [0.139, 0.098, 0.099],
+ [0.116, 0.102, 0.097],
+ [0.321, 0.25, 0.236],
+ [0.372, 0.364, 0.366],
+ [0.128, 0.09, 0.086],
+ [0.152, 0.088, 0.084],
+ [0.357, 0.302, 0.296],
+ [0.376, 0.379, 0.378],
+ [0.142, 0.136, 0.134],
+ [0.158, 0.162, 0.163],
+ [0.388, 0.383, 0.376],
+ [0.569, 0.54, 0.536],
+ [0.389, 0.394, 0.415],
+ [0.322, 0.27, 0.273],
+ [0.634, 0.605, 0.602],
+ [0.523, 0.534, 0.538],
+ [1.77, 1.643, 1.67],
+ [0.102, 0.096, 0.083],
+ [0.794, 0.735, 0.732],
+ [0.66, 0.662, 0.659],
+ [1.21, 1.195, 1.176],
+ [0.472, 0.479, 0.469],
+ [0.186, 0.185, 0.188],
+ [0.229, 0.226, 0.229],
+ [0.142, 0.139, 0.138],
+ [0.774, 0.775, 0.772],
+ [5.37, 5.366, 5.386],
+ [0.11, 0.11, 0.111],
+ [0.425, 0.421, 0.415],
+ [0.478, 0.447, 0.441],
+ [1.076, 0.99, 0.968],
+ [1.328, 1.318, 1.34],
+ [1.368, 1.356, 1.345],
+ [0.331, 0.369, 0.452],
+ [0.196, 0.183, 0.178],
+ [0.16, 0.16, 0.158],
+ [0.138, 0.137, 0.138],
+ [0.302, 0.28, 0.271],
+ [0.1, 0.102, 0.103],
+ [0.1, 0.099, 0.102],
+ [0.213, 0.212, 0.214]
+]
+}
+
diff --git a/arc/results/c8g.metal-48xl.json b/arc/results/c8g.metal-48xl.json
new file mode 100644
index 000000000..86f2a1036
--- /dev/null
+++ b/arc/results/c8g.metal-48xl.json
@@ -0,0 +1,57 @@
+{
+ "system": "Arc",
+ "date": "2025-10-16",
+ "machine": "c8g.metal-48xl",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [0.071, 0.071, 0.06],
+ [0.075, 0.074, 0.066],
+ [0.083, 0.075, 0.072],
+ [0.081, 0.103, 0.083],
+ [0.262, 0.326, 0.276],
+ [0.282, 0.281, 0.344],
+ [0.075, 0.075, 0.074],
+ [0.074, 0.072, 0.075],
+ [0.15, 0.252, 0.282],
+ [0.346, 0.399, 0.413],
+ [0.195, 0.158, 0.114],
+ [0.103, 0.098, 0.093],
+ [0.228, 0.259, 0.213],
+ [0.311, 0.571, 0.531],
+ [0.236, 0.251, 0.214],
+ [0.152, 0.145, 0.162],
+ [0.341, 0.272, 0.335],
+ [0.45, 0.368, 0.608],
+ [0.635, 0.56, 0.883],
+ [0.078, 0.07, 0.099],
+ [0.241, 0.249, 0.232],
+ [0.196, 0.271, 0.197],
+ [0.311, 0.29, 0.289],
+ [0.443, 0.457, 0.436],
+ [0.171, 0.152, 0.162],
+ [0.113, 0.128, 0.142],
+ [0.121, 0.107, 0.113],
+ [0.26, 0.25, 0.251],
+ [1.797, 2.571, 2.542],
+ [0.166, 0.14, 0.102],
+ [0.204, 0.191, 0.229],
+ [0.23, 0.244, 0.232],
+ [0.805, 0.552, 0.69],
+ [0.541, 0.534, 0.571],
+ [0.696, 0.582, 0.567],
+ [0.153, 0.163, 0.26],
+ [0.171, 0.167, 0.165],
+ [0.142, 0.14, 0.141],
+ [0.114, 0.116, 0.112],
+ [0.257, 0.256, 0.262],
+ [0.08, 0.089, 0.086],
+ [0.078, 0.105, 0.084],
+ [0.228, 0.205, 0.209]
+]
+}
+
diff --git a/arc/run.sh b/arc/run.sh
new file mode 100755
index 000000000..8b8ac56ff
--- /dev/null
+++ b/arc/run.sh
@@ -0,0 +1,95 @@
+#!/bin/bash
+# Arc ClickBench Benchmark Runner
+# Queries Arc via HTTP API using Apache Arrow columnar format
+
+TRIES=3
+DATABASE="${DATABASE:-clickbench}"
+TABLE="${TABLE:-hits}"
+ARC_URL="${ARC_URL:-http://localhost:8000}"
+ARC_API_KEY="${ARC_API_KEY:-benchmark-test-key}"
+
+# Check if Arc is running
+echo "Checking if Arc is running at $ARC_URL..." >&2
+if ! curl -s -f "$ARC_URL/health" > /dev/null 2>&1; then
+ echo "Error: Arc is not running at $ARC_URL" >&2
+ echo "Please start Arc first or set ARC_URL environment variable" >&2
+ exit 1
+fi
+
+echo "Arc is running. Querying table: $DATABASE.$TABLE (Apache Arrow)" >&2
+echo "Using API key: ${ARC_API_KEY:0:20}..." >&2
+
+python3 << EOF
+import requests
+import time
+import sys
+
+try:
+ import pyarrow as pa
+except ImportError:
+ print("Error: pyarrow is required for Arrow format", file=sys.stderr)
+ print("Install with: pip install pyarrow", file=sys.stderr)
+ sys.exit(1)
+
+ARC_URL = "$ARC_URL"
+API_KEY = "$ARC_API_KEY"
+DATABASE = "$DATABASE"
+TABLE = "$TABLE"
+
+# Headers for API requests
+headers = {
+ "x-api-key": API_KEY,
+ "Content-Type": "application/json"
+}
+
+# Read queries
+with open('queries.sql') as f:
+ content = f.read()
+
+# Remove comment lines
+lines = [line for line in content.split('\n') if not line.strip().startswith('--')]
+clean_content = '\n'.join(lines)
+
+# Split by semicolons and filter empties
+queries = []
+for query in clean_content.split(';'):
+ query = query.strip()
+ if query:
+ queries.append(query)
+
+print(f"Running {len(queries)} queries via Apache Arrow API...", file=sys.stderr)
+
+# Run each query 3 times
+for i, query_sql in enumerate(queries, 1):
+ for run in range(3):
+ try:
+ start = time.perf_counter()
+
+ response = requests.post(
+ f"{ARC_URL}/query/arrow",
+ headers=headers,
+ json={"sql": query_sql},
+ timeout=300
+ )
+
+ if response.status_code == 200:
+ # Parse Arrow IPC stream to ensure data is received
+ reader = pa.ipc.open_stream(response.content)
+ arrow_table = reader.read_all()
+ elapsed = time.perf_counter() - start
+ print(f"{elapsed:.4f}")
+ else:
+ print("null")
+ if run == 0:
+ print(f"Query {i} failed: {response.status_code} - {response.text[:200]}", file=sys.stderr)
+ except requests.exceptions.Timeout:
+ print("null")
+ if run == 0:
+ print(f"Query {i} timed out", file=sys.stderr)
+ except Exception as e:
+ print("null")
+ if run == 0:
+ print(f"Query {i} error: {e}", file=sys.stderr)
+
+print("Benchmark complete!", file=sys.stderr)
+EOF
diff --git a/arc/template.json b/arc/template.json
new file mode 100644
index 000000000..8499adaba
--- /dev/null
+++ b/arc/template.json
@@ -0,0 +1,6 @@
+{
+ "system": "Arc",
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Python", "column-oriented", "time-series"]
+}
diff --git a/clickhouse-cloud/results/aws.1.12.json b/clickhouse-cloud/results/aws.1.12.json
index 748e4decf..5b97d26cc 100644
--- a/clickhouse-cloud/results/aws.1.12.json
+++ b/clickhouse-cloud/results/aws.1.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 334.795,
- "data_size": 9942499635,
+ "load_time": 372.939,
+ "data_size": 9942620374,
"result": [
-[0.003, 0.024, 0.020], [0.062, 0.034, 0.021], [0.234, 0.170, 0.160], [0.400, 0.361, 0.337], [1.914, 1.726, 1.974], [3.329, 2.683, 2.452], [0.061, 0.052, 0.053], [0.033, 0.028, 0.029], [1.828, 1.781, 1.672], [3.049, 2.626, 2.623], [0.703, 0.698, 0.637], [0.800, 0.814, 0.785], [2.694, 2.521, 2.601], [4.691, 4.026, 3.977], [3.703, 3.662, 3.734], [1.852, 2.019, 1.879], [15.654, 14.351, 14.157], [6.971, 10.610, 9.950], [25.422, 26.567, 25.391], [0.067, 0.007, 0.007], [4.996, 2.235, 2.127], [5.888, 0.531, 0.465], [6.307, 3.077, 2.870], [2.808, 2.842, 2.700], [1.298, 1.352, 1.349], [0.913, 1.039, 0.926], [1.288, 1.601, 1.358], [4.626, 4.510, 4.912], [38.966, 35.696, 36.820], [0.116, 0.115, 0.115], [1.881, 1.840, 1.827], [2.328, 2.162, 2.196], [16.562, 15.305, 14.940], [15.258, 14.973, 15.435], [14.502, 15.542, 15.273], [1.079, 1.181, 1.113], [0.113, 0.102, 0.106], [0.074, 0.052, 0.052], [0.049, 0.048, 0.046], [0.233, 0.196, 0.185], [0.030, 0.027, 0.036], [0.023, 0.021, 0.024], [0.022, 0.020, 0.018]
+[0.002, 0.002, 0.002], [0.027, 0.022, 0.020], [0.142, 0.138, 0.147], [0.259, 0.262, 0.262], [1.378, 1.431, 1.358], [2.376, 2.586, 2.483], [0.053, 0.052, 0.053], [0.026, 0.026, 0.026], [1.840, 1.832, 1.890], [2.326, 2.322, 2.297], [0.646, 0.631, 0.680], [0.755, 0.887, 0.764], [2.183, 2.320, 2.289], [3.931, 3.903, 3.859], [2.971, 2.576, 2.570], [1.464, 1.417, 1.537], [10.469, 6.288, 10.082], [4.175, 8.289, 7.295], [18.438, 18.431, 18.118], [0.064, 0.007, 0.007], [4.836, 1.967, 1.880], [4.899, 0.427, 0.403], [5.841, 2.615, 2.710], [2.861, 2.722, 2.497], [0.971, 0.954, 0.958], [0.617, 0.606, 0.615], [0.946, 0.926, 0.958], [3.401, 3.118, 3.145], [19.917, 19.532, 20.176], [0.117, 0.112, 0.112], [1.870, 1.689, 1.756], [2.239, 2.191, 2.137], [13.451, 14.448, 14.452], [14.039, 13.247, 13.413], [13.409, 13.653, 13.193], [0.760, 0.703, 0.787], [0.105, 0.097, 0.092], [0.049, 0.045, 0.050], [0.046, 0.046, 0.046], [0.192, 0.190, 0.193], [0.029, 0.026, 0.024], [0.025, 0.022, 0.023], [0.019, 0.018, 0.018]
]
}
diff --git a/clickhouse-cloud/results/aws.1.8.json b/clickhouse-cloud/results/aws.1.8.json
index d8208eed1..d8c67805f 100644
--- a/clickhouse-cloud/results/aws.1.8.json
+++ b/clickhouse-cloud/results/aws.1.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 499.920,
- "data_size": 9944976229,
+ "load_time": 521.892,
+ "data_size": 9947836139,
"result": [
-[0.005, 0.002, 0.002], [0.058, 0.038, 0.056], [0.386, 0.412, 0.552], [0.741, 0.717, 0.785], [3.780, 3.454, 3.595], [6.747, 6.979, 6.573], [0.130, 0.115, 0.145], [0.054, 0.068, 0.037], [3.657, 3.749, 3.720], [4.350, 4.739, 4.474], [1.079, 1.083, 1.130], [1.195, 1.547, 1.402], [4.478, 4.313, 4.353], [7.481, 12.024, 7.080], [10.152, 6.952, 6.598], [3.708, 3.825, 3.964], [23.340, 22.613, 22.193], [12.531, 10.857, 9.773], [27.510, 27.315, 26.960], [0.088, 0.010, 0.011], [5.971, 2.294, 2.421], [6.156, 0.523, 0.521], [7.282, 3.152, 3.361], [3.057, 2.899, 2.864], [1.723, 1.516, 1.549], [1.053, 1.043, 1.040], [1.498, 1.484, 1.515], [5.452, 5.169, 4.896], [55.000, 54.614, 54.050], [0.174, 0.166, 0.179], [2.780, 2.775, 2.601], [3.380, 3.388, 3.268], [22.956, 21.806, 21.953], [23.160, 22.610, 23.817], [22.732, 22.505, 21.722], [1.393, 1.289, 1.159], [0.140, 0.150, 0.153], [0.068, 0.068, 0.067], [0.064, 0.061, 0.065], [0.269, 0.271, 0.266], [0.035, 0.029, 0.034], [0.028, 0.031, 0.027], [0.025, 0.022, 0.023]
+[0.003, 0.002, 0.002], [0.073, 0.044, 0.026], [0.436, 0.357, 0.339], [0.792, 0.937, 0.710], [4.619, 4.026, 4.142], [6.615, 6.401, 7.000], [0.111, 0.121, 0.180], [0.042, 0.036, 0.037], [3.747, 3.614, 3.812], [4.505, 4.501, 4.382], [1.104, 1.129, 1.123], [1.330, 1.397, 1.284], [4.449, 4.208, 4.024], [6.611, 11.086, 6.625], [5.050, 4.630, 4.575], [2.643, 2.483, 2.085], [19.590, 20.482, 18.144], [13.015, 12.952, 13.689], [23.928, 22.559, 21.063], [0.084, 0.011, 0.011], [5.391, 2.213, 2.578], [5.687, 0.460, 0.567], [6.542, 3.004, 2.972], [2.840, 2.701, 2.749], [1.455, 1.411, 1.443], [0.959, 0.941, 0.948], [1.424, 1.443, 1.449], [4.778, 5.294, 5.231], [30.406, 30.336, 30.421], [0.169, 0.182, 0.180], [2.756, 3.065, 3.274], [3.827, 3.788, 3.467], [21.093, 23.407, 22.446], [22.461, 22.486, 22.157], [21.940, 22.045, 21.034], [1.084, 0.954, 0.973], [0.158, 0.147, 0.153], [0.065, 0.065, 0.069], [0.066, 0.061, 0.061], [0.299, 0.286, 0.293], [0.040, 0.032, 0.033], [0.027, 0.028, 0.026], [0.027, 0.023, 0.023]
]
}
diff --git a/clickhouse-cloud/results/aws.2.12.json b/clickhouse-cloud/results/aws.2.12.json
index ad1c67527..b9a4fae63 100644
--- a/clickhouse-cloud/results/aws.2.12.json
+++ b/clickhouse-cloud/results/aws.2.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 318.155,
- "data_size": 9946120462,
+ "load_time": 321.720,
+ "data_size": 9941327612,
"result": [
-[0.021, 0.013, 0.039], [0.102, 0.043, 0.225], [0.360, 0.300, 0.287], [0.356, 0.422, 0.218], [1.055, 1.040, 1.026], [2.221, 2.653, 1.866], [0.115, 0.051, 0.051], [0.043, 0.142, 0.037], [2.358, 2.391, 2.109], [2.268, 2.077, 2.307], [0.631, 0.570, 0.489], [0.818, 0.713, 0.618], [2.549, 1.825, 1.830], [4.198, 3.951, 2.743], [2.807, 3.502, 2.802], [1.953, 1.725, 1.664], [6.334, 9.059, 6.298], [7.006, 6.664, 7.313], [17.971, 24.901, 23.878], [0.062, 0.170, 0.007], [12.547, 1.468, 1.455], [5.785, 0.463, 3.810], [19.587, 2.191, 4.475], [32.062, 2.038, 4.260], [1.146, 0.998, 1.046], [0.691, 0.682, 0.688], [0.995, 1.024, 1.061], [3.285, 3.297, 3.365], [43.259, 35.553, 35.500], [0.121, 0.118, 0.238], [2.392, 1.833, 2.171], [5.358, 2.571, 2.479], [14.690, 16.282, 14.550], [15.419, 14.292, 14.038], [14.424, 14.949, 14.887], [1.054, 1.014, 0.973], [0.189, 0.103, 0.104], [0.053, 0.052, 0.049], [0.046, 0.048, 0.047], [0.209, 0.202, 0.195], [0.031, 0.135, 0.031], [0.022, 0.025, 0.022], [0.020, 0.019, 0.018]
+[0.002, 0.003, 0.002], [0.186, 0.022, 0.047], [0.231, 0.271, 0.113], [0.501, 0.209, 0.209], [1.000, 1.392, 1.383], [2.403, 2.574, 2.497], [0.140, 0.050, 0.048], [0.089, 0.032, 0.027], [1.467, 1.347, 2.152], [2.577, 2.503, 2.302], [0.649, 0.586, 0.495], [0.792, 0.686, 0.826], [2.364, 1.884, 1.593], [4.047, 2.613, 2.508], [2.935, 2.858, 2.211], [1.473, 1.544, 1.070], [7.219, 4.651, 7.061], [8.537, 7.583, 3.060], [19.252, 14.659, 13.043], [0.198, 0.007, 0.064], [4.611, 10.763, 1.969], [3.583, 0.340, 5.084], [11.035, 6.408, 2.652], [2.876, 35.984, 1.893], [0.993, 0.950, 1.421], [0.920, 0.922, 0.750], [0.965, 0.978, 0.947], [10.698, 3.144, 3.335], [25.458, 20.289, 20.117], [0.276, 0.114, 0.112], [2.727, 1.869, 1.689], [2.445, 2.344, 4.860], [14.772, 14.810, 14.787], [14.121, 13.953, 14.339], [13.513, 13.471, 13.290], [0.814, 0.691, 0.740], [0.284, 0.101, 0.100], [0.051, 0.175, 0.049], [0.044, 0.167, 0.045], [0.321, 0.194, 0.202], [0.027, 0.196, 0.023], [0.146, 0.025, 0.024], [0.021, 0.177, 0.017]
]
}
diff --git a/clickhouse-cloud/results/aws.2.120.json b/clickhouse-cloud/results/aws.2.120.json
index 59543b9c9..2760ecf4c 100644
--- a/clickhouse-cloud/results/aws.2.120.json
+++ b/clickhouse-cloud/results/aws.2.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 58.345,
- "data_size": 9952504953,
+ "load_time": 287.317,
+ "data_size": ),
"result": [
-[0.002, 0.002, 0.002], [0.017, 0.367, 0.013], [0.024, 0.023, 0.024], [0.432, 0.037, 0.036], [0.201, 0.194, 0.181], [0.249, 0.227, 0.389], [0.013, 0.013, 0.014], [0.017, 0.089, 0.016], [0.246, 0.233, 0.443], [0.294, 0.438, 0.274], [0.128, 0.208, 0.118], [0.138, 0.136, 0.133], [0.445, 0.270, 0.265], [0.384, 0.424, 0.395], [0.433, 0.321, 0.321], [0.228, 0.213, 0.202], [0.754, 0.782, 0.746], [0.571, 0.623, 0.648], [1.496, 1.702, 1.364], [0.073, 0.005, 0.005], [1.150, 0.409, 0.218], [0.439, 0.446, 0.064], [0.526, 1.410, 0.303], [0.403, 0.396, 0.397], [0.139, 0.139, 0.139], [0.105, 0.102, 0.104], [0.133, 0.137, 0.135], [0.396, 0.404, 0.473], [4.376, 3.591, 3.705], [0.037, 0.036, 0.036], [0.255, 0.570, 0.267], [0.376, 0.374, 0.989], [1.338, 1.151, 1.365], [1.085, 1.110, 1.138], [1.097, 1.072, 1.100], [0.184, 0.181, 0.155], [0.138, 0.039, 0.049], [0.029, 0.026, 0.026], [0.186, 0.029, 0.029], [0.067, 0.265, 0.068], [0.203, 0.018, 0.017], [0.017, 0.167, 0.017], [0.015, 0.013, 0.014]
+
]
}
diff --git a/clickhouse-cloud/results/aws.2.16.json b/clickhouse-cloud/results/aws.2.16.json
index 903f8a2da..6b60b6fb5 100644
--- a/clickhouse-cloud/results/aws.2.16.json
+++ b/clickhouse-cloud/results/aws.2.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 240.639,
- "data_size": 9941146231,
+ "load_time": 349.748,
+ "data_size": 9946377514,
"result": [
-[0.002, 0.002, 0.002], [0.508, 0.023, 0.055], [0.603, 0.093, 0.095], [0.448, 0.165, 0.173], [0.799, 1.304, 0.806], [1.578, 1.438, 1.333], [0.041, 0.042, 0.106], [0.024, 0.083, 0.025], [1.204, 1.190, 1.063], [1.808, 1.742, 1.592], [0.500, 0.387, 0.382], [0.582, 0.570, 0.472], [1.814, 1.404, 1.673], [2.994, 2.650, 2.562], [2.260, 2.004, 1.913], [1.491, 1.026, 1.009], [4.668, 4.787, 5.718], [3.471, 4.751, 4.420], [9.635, 12.849, 13.213], [0.051, 0.006, 0.007], [3.248, 9.322, 1.094], [2.826, 3.603, 0.289], [4.074, 2.121, 1.926], [28.951, 1.456, 1.441], [0.723, 0.747, 1.045], [0.596, 0.599, 0.498], [0.739, 0.932, 0.734], [2.488, 3.068, 2.411], [33.978, 28.139, 32.018], [0.337, 0.092, 0.091], [1.327, 2.399, 1.379], [3.773, 2.090, 2.011], [12.764, 11.078, 11.900], [12.661, 6.703, 6.703], [6.515, 11.378, 6.630], [0.823, 0.859, 0.718], [0.297, 0.085, 0.078], [0.190, 0.043, 0.044], [0.043, 0.153, 0.042], [0.239, 0.135, 0.133], [0.177, 0.024, 0.023], [0.022, 0.126, 0.020], [0.134, 0.019, 0.024]
+[0.002, 0.002, 0.002], [0.019, 0.017, 0.016], [0.094, 0.241, 0.099], [0.376, 0.166, 0.164], [1.010, 0.924, 0.791], [1.489, 1.520, 1.539], [0.039, 0.039, 0.038], [0.021, 0.025, 0.024], [1.209, 1.282, 1.164], [1.393, 1.641, 1.535], [0.439, 0.502, 0.387], [0.504, 0.539, 0.573], [1.572, 1.766, 1.299], [2.074, 2.196, 2.462], [1.684, 1.464, 1.691], [1.009, 0.884, 0.915], [3.656, 3.710, 4.247], [3.057, 2.288, 2.210], [9.270, 9.303, 6.143], [0.154, 0.010, 0.010], [2.479, 8.667, 1.056], [2.724, 2.971, 0.258], [9.361, 1.554, 3.071], [26.223, 1.494, 1.369], [0.735, 0.721, 0.715], [0.492, 0.457, 0.451], [0.706, 0.709, 0.711], [2.242, 2.379, 2.251], [19.689, 14.885, 14.538], [0.090, 0.087, 0.172], [1.712, 1.295, 1.257], [1.774, 3.712, 1.687], [12.318, 9.942, 11.200], [6.797, 6.214, 10.052], [7.072, 5.830, 6.725], [0.663, 0.604, 0.509], [0.081, 0.068, 0.087], [0.044, 0.039, 0.045], [0.044, 0.039, 0.045], [0.151, 0.139, 0.138], [0.130, 0.023, 0.022], [0.021, 0.021, 0.026], [0.019, 0.016, 0.016]
]
}
diff --git a/clickhouse-cloud/results/aws.2.236.json b/clickhouse-cloud/results/aws.2.236.json
index 6db280e7d..dcd7ce128 100644
--- a/clickhouse-cloud/results/aws.2.236.json
+++ b/clickhouse-cloud/results/aws.2.236.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 236GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 55.262,
- "data_size": 9952463416,
+ "load_time": 178.006,
+ "data_size": 9946306381,
"result": [
-[0.002, 0.002, 0.002], [0.018, 0.472, 0.016], [0.220, 0.023, 0.022], [0.217, 0.027, 0.028], [0.124, 0.115, 0.110], [0.312, 0.168, 0.292], [0.015, 0.015, 0.015], [0.131, 0.019, 0.018], [0.409, 0.332, 0.293], [0.308, 0.361, 0.313], [0.295, 0.100, 0.109], [0.203, 0.110, 0.099], [0.233, 0.196, 0.162], [0.253, 0.259, 0.278], [0.227, 0.216, 0.312], [0.123, 0.118, 0.118], [0.470, 0.400, 0.469], [0.283, 0.299, 0.312], [1.024, 0.716, 0.721], [0.016, 0.005, 0.063], [0.797, 0.146, 0.155], [0.281, 0.054, 0.051], [0.707, 0.365, 0.200], [0.403, 0.315, 0.295], [0.099, 0.100, 0.100], [0.069, 0.080, 0.079], [0.100, 0.100, 0.100], [0.358, 0.268, 0.269], [2.327, 1.973, 1.901], [0.258, 0.042, 0.041], [0.191, 0.184, 0.191], [0.637, 0.258, 0.230], [0.979, 0.835, 0.843], [0.807, 0.772, 0.762], [0.732, 0.741, 0.793], [0.099, 0.101, 0.092], [0.172, 0.047, 0.050], [0.031, 0.031, 0.030], [0.031, 0.031, 0.131], [0.197, 0.081, 0.082], [0.019, 0.019, 0.185], [0.019, 0.018, 0.018], [0.015, 0.015, 0.015]
+[0.002, 0.002, 0.002], [0.315, 0.016, 0.051], [0.022, 0.224, 0.020], [0.430, 0.025, 0.026], [0.125, 0.109, 0.124], [0.401, 0.169, 0.171], [0.080, 0.013, 0.014], [0.016, 0.016, 0.015], [0.298, 0.415, 0.273], [0.310, 0.340, 0.295], [0.232, 0.113, 0.099], [0.208, 0.101, 0.097], [0.179, 0.152, 0.203], [0.241, 0.253, 0.256], [0.285, 0.194, 0.206], [0.097, 0.096, 0.093], [0.428, 0.398, 0.363], [0.258, 0.232, 0.239], [1.256, 0.605, 0.632], [0.100, 0.005, 0.016], [0.257, 0.143, 0.141], [1.003, 0.789, 0.288], [0.911, 0.346, 0.198], [0.359, 0.291, 24.218], [0.106, 0.103, 0.156], [0.081, 0.080, 0.079], [0.104, 0.103, 0.104], [0.277, 0.277, 0.277], [1.098, 1.483, 1.079], [0.039, 0.038, 0.039], [0.189, 0.196, 0.324], [0.562, 0.255, 0.244], [0.865, 0.881, 0.866], [0.682, 0.681, 0.735], [0.713, 0.685, 0.701], [0.074, 0.072, 0.068], [0.105, 0.042, 0.043], [0.029, 0.028, 0.029], [0.029, 0.028, 0.029], [0.075, 0.072, 0.075], [0.016, 0.016, 0.016], [0.016, 0.104, 0.016], [0.017, 0.013, 0.017]
]
}
diff --git a/clickhouse-cloud/results/aws.2.32.json b/clickhouse-cloud/results/aws.2.32.json
index bbbbd94a5..dc5379635 100644
--- a/clickhouse-cloud/results/aws.2.32.json
+++ b/clickhouse-cloud/results/aws.2.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 106.553,
- "data_size": 9946797199,
+ "load_time": 302.345,
+ "data_size": ),
"result": [
-[0.002, 0.003, 0.019], [0.215, 0.016, 0.015], [0.514, 0.056, 0.082], [0.233, 0.085, 0.104], [0.595, 0.516, 0.481], [0.837, 0.831, 0.826], [0.100, 0.024, 0.024], [0.018, 0.018, 0.018], [0.622, 0.539, 0.640], [0.690, 0.947, 0.705], [0.322, 0.247, 0.243], [0.299, 0.289, 0.287], [0.731, 0.748, 0.786], [1.182, 1.041, 1.151], [0.994, 1.018, 1.097], [0.690, 0.513, 0.594], [2.339, 2.649, 2.408], [1.565, 1.523, 1.559], [4.590, 4.638, 4.693], [0.029, 0.099, 0.005], [4.438, 0.578, 0.568], [1.428, 0.135, 0.134], [1.833, 5.340, 0.800], [1.721, 37.517, 0.892], [0.424, 0.405, 0.403], [0.286, 0.260, null], [0.406, 0.401, 0.422], [1.428, 1.267, 1.201], [15.666, 13.090, 13.337], [0.404, 0.060, 0.060], [0.723, 1.351, 0.750], [2.051, 1.046, 0.920], [3.845, 2.711, 2.520], [3.213, 3.252, 3.183], [3.144, 3.294, 5.668], [0.458, 0.469, 0.451], [0.196, 0.050, 0.047], [0.150, 0.031, 0.031], [0.032, 0.030, 0.139], [0.081, 0.083, 0.206], [0.167, 0.018, 0.018], [0.017, 0.128, 0.018], [0.016, 0.120, 0.017]
+
]
}
diff --git a/clickhouse-cloud/results/aws.2.64.json b/clickhouse-cloud/results/aws.2.64.json
index b3ce08757..40653170c 100644
--- a/clickhouse-cloud/results/aws.2.64.json
+++ b/clickhouse-cloud/results/aws.2.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 59.979,
- "data_size": 9937891951,
+ "load_time": 290.386,
+ "data_size": ),
"result": [
-[0.003, 0.002, 0.002], [0.015, 0.013, 0.251], [0.271, 0.033, 0.034], [0.052, 0.211, 0.053], [0.253, 0.252, 0.252], [0.529, 0.404, 0.426], [0.107, 0.017, 0.017], [0.052, 0.016, 0.015], [0.546, 0.372, 0.346], [0.417, 0.437, 0.437], [0.156, 0.250, 0.159], [0.287, 0.185, 0.182], [0.469, 0.412, 0.422], [0.628, 0.595, 0.638], [0.547, 0.661, 0.627], [0.289, 0.254, 0.292], [1.137, 1.121, 1.161], [0.819, 0.822, 0.892], [2.728, 2.296, 2.522], [0.018, 0.076, 0.005], [2.043, 0.322, 0.687], [0.747, 0.085, 0.085], [0.915, 2.539, 0.460], [0.531, 32.647, 0.523], [0.214, 0.224, 0.212], [0.163, 0.161, 0.168], [0.212, 0.211, 0.247], [0.658, 0.676, 0.676], [8.167, 7.159, 7.021], [0.043, 0.043, 0.042], [0.679, 0.418, 0.415], [0.548, 0.525, 1.293], [1.625, 1.911, 1.361], [1.685, 1.907, 1.784], [1.873, 1.774, 1.789], [0.389, 0.242, 0.278], [0.040, 0.267, 0.043], [0.026, 0.030, 0.141], [0.120, 0.027, 0.029], [0.071, 0.280, 0.068], [0.019, 0.019, 0.237], [0.114, 0.016, 0.017], [0.013, 0.013, 0.194]
+Code: 1001. DB::Exception: Received from q32rur543h.ap-southeast-2.aws.clickhouse.cloud:9440. DB::Exception: parquet::ParquetStatusException: IOError: Poco::Exception. Code: 1000, e.code() = 101, Net Exception: Network is unreachable: [2606:4700:3108::ac42:2b07]:443 (version 25.8.1.8490 (official build)). (STD_EXCEPTION
]
}
diff --git a/clickhouse-cloud/results/aws.2.8.json b/clickhouse-cloud/results/aws.2.8.json
index 903b3b956..ce149d28d 100644
--- a/clickhouse-cloud/results/aws.2.8.json
+++ b/clickhouse-cloud/results/aws.2.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 482.483,
- "data_size": 9943634620,
+ "load_time": 487.290,
+ "data_size": 9945770069,
"result": [
-[0.002, 0.015, 0.002], [0.033, 0.163, 0.046], [0.260, 0.282, 0.189], [0.447, 0.455, 0.465], [1.982, 2.507, 2.398], [3.342, 4.586, 4.365], [0.139, 0.073, 0.072], [0.036, 0.036, 0.035], [3.239, 3.474, 3.383], [4.058, 3.170, 4.218], [1.153, 0.839, 0.733], [1.526, 0.977, 0.954], [2.647, 4.515, 4.479], [4.155, 6.671, 7.050], [5.674, 4.223, 5.646], [2.962, 2.958, 2.868], [19.511, 14.962, 14.324], [17.144, 14.839, 14.768], [30.210, 31.285, 25.850], [0.085, 0.214, 0.010], [5.179, 18.508, 2.437], [5.715, 0.537, 0.509], [21.309, 6.538, 3.046], [28.008, 2.904, 2.873], [1.754, 1.449, 1.448], [1.002, 0.992, 0.961], [1.479, 1.429, 1.523], [4.922, 4.922, 4.738], [54.170, 64.798, 53.582], [0.165, 0.242, 0.165], [2.599, 3.613, 2.488], [3.691, 3.482, 3.215], [20.351, 20.255, 19.727], [21.343, 22.225, 22.050], [21.317, 21.526, 21.630], [1.527, 1.487, 1.348], [0.175, 0.146, 0.155], [0.065, 0.066, 0.066], [0.070, 0.066, 0.061], [0.296, 0.430, 0.268], [0.035, 0.033, 0.033], [0.028, 0.157, 0.026], [0.026, 0.023, 0.024]
+[0.002, 0.048, 0.016], [0.044, 0.081, 0.026], [0.488, 0.423, 0.233], [0.880, 0.714, 0.655], [1.545, 1.722, 1.412], [3.084, 2.702, 4.123], [0.145, 0.070, 0.070], [0.119, 0.038, 0.034], [2.238, 3.172, 1.994], [3.536, 2.567, 3.482], [1.039, 0.835, 0.992], [1.282, 0.959, 0.855], [2.487, 2.591, 2.506], [3.879, 6.334, 3.608], [2.878, 3.199, 2.677], [1.543, 1.487, 1.801], [9.612, 10.220, 10.782], [7.398, 8.104, 7.209], [21.457, 20.016, 19.298], [0.217, 0.009, 0.009], [16.544, 4.815, 2.156], [5.878, 0.502, 0.533], [17.311, 6.041, 2.987], [36.574, 2.760, 2.962], [1.415, 1.409, 1.399], [0.948, 0.913, 0.914], [1.408, 1.562, 1.448], [4.456, 4.820, 4.773], [29.227, 29.546, 39.782], [0.161, 0.157, 0.157], [2.706, 3.488, 2.510], [3.559, 3.230, 3.297], [32.714, 29.853, 19.898], [22.580, 20.299, 22.640], [20.445, 21.845, 20.514], [1.064, 0.978, 0.996], [0.212, 0.155, 0.148], [0.070, 0.066, 0.065], [0.060, 0.103, 0.061], [0.295, 0.267, 0.289], [0.164, 0.037, 0.033], [0.029, 0.117, 0.026], [0.024, 0.026, 0.024]
]
}
diff --git a/clickhouse-cloud/results/aws.3.12.json b/clickhouse-cloud/results/aws.3.12.json
index c672b2538..7c9f00f08 100644
--- a/clickhouse-cloud/results/aws.3.12.json
+++ b/clickhouse-cloud/results/aws.3.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 316.908,
- "data_size": 9941060505,
+ "load_time": 322.448,
+ "data_size": 9943329734,
"result": [
-[0.002, 0.002, 0.002], [0.092, 0.061, 0.386], [0.273, 0.167, 0.118], [0.393, 0.327, 0.477], [1.745, 1.967, 1.042], [2.388, 2.428, 2.135], [0.138, 0.050, 0.050], [0.030, 0.098, 0.027], [1.390, 1.615, 1.242], [1.652, 1.664, 1.668], [0.575, 0.596, 0.540], [0.662, 0.624, 0.589], [1.773, 2.661, 1.846], [2.537, 2.627, 2.696], [2.558, 2.342, 3.638], [1.246, 1.180, 1.789], [14.297, 5.840, 8.897], [4.372, 6.715, 5.015], [18.529, 15.821, 16.099], [0.071, 0.168, 0.007], [4.809, 12.706, 1.479], [7.752, 0.320, 0.407], [12.630, 1.979, 1.942], [32.115, 31.216, 18.811], [1.042, 1.318, 1.208], [0.677, 0.663, 0.645], [0.962, 1.007, 0.947], [3.087, 3.319, 3.082], [40.769, 34.823, 34.592], [0.264, 0.111, 0.110], [1.887, 2.166, 1.887], [5.193, 2.691, 3.577], [17.464, 13.874, 14.055], [14.064, 13.148, 13.642], [14.446, 13.467, 14.196], [0.972, 0.931, 0.982], [0.165, 0.104, 0.100], [0.186, 0.050, 0.135], [0.046, 0.048, 0.050], [0.204, 0.195, 0.348], [0.181, 0.029, 0.027], [0.021, 0.021, 0.093], [0.019, 0.018, 0.018]
+[0.002, 0.002, 0.002], [0.294, 0.021, 0.169], [0.207, 0.175, 0.189], [0.583, 0.364, 0.440], [1.318, 1.052, 1.034], [2.509, 2.426, 2.286], [0.135, 0.054, 0.098], [0.105, 0.028, 0.081], [1.515, 1.422, 1.353], [2.440, 1.737, 1.570], [0.665, 0.585, 0.553], [0.685, 0.793, 0.644], [2.586, 1.875, 2.257], [4.115, 2.561, 2.509], [2.278, 1.977, 3.080], [1.056, 1.501, 1.081], [4.829, 7.477, 11.090], [3.832, 4.437, 8.468], [15.484, 14.275, 13.718], [0.208, 0.007, 0.007], [10.842, 1.427, 5.054], [8.369, 3.617, 0.325], [10.873, 1.988, 7.834], [38.973, 26.251, 1.843], [1.664, 1.187, 0.977], [0.729, 0.629, 0.622], [0.933, 0.990, 0.937], [3.317, 7.983, 3.368], [25.885, 20.391, 23.797], [0.118, 0.193, 0.113], [1.762, 2.270, 2.000], [4.739, 3.973, 2.722], [17.732, 18.492, 15.630], [14.286, 15.619, 14.369], [14.464, 14.844, 14.706], [0.813, 0.747, 0.739], [0.181, 0.114, 0.259], [0.174, 0.049, 0.048], [0.045, 0.048, 0.056], [0.208, 0.337, 0.189], [0.031, 0.028, 0.028], [0.025, 0.195, 0.024], [0.019, 0.019, 0.020]
]
}
diff --git a/clickhouse-cloud/results/aws.3.120.json b/clickhouse-cloud/results/aws.3.120.json
index ca3858fe2..71ef74ee6 100644
--- a/clickhouse-cloud/results/aws.3.120.json
+++ b/clickhouse-cloud/results/aws.3.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 59.832,
- "data_size": 9936791046,
+ "load_time": 236.985,
+ "data_size": 9944817910,
"result": [
-[0.002, 0.002, 0.002], [0.442, 0.050, 0.050], [0.134, 0.392, 0.027], [0.353, 0.034, 0.034], [0.270, 0.202, 0.178], [0.372, 0.280, 0.276], [0.015, 0.015, 0.129], [0.075, 0.015, 0.050], [0.424, 0.350, 0.246], [0.307, 0.300, 0.394], [0.258, 0.182, 0.124], [0.277, 0.147, 0.125], [0.377, 0.310, 0.284], [0.477, 0.468, 0.419], [0.456, 0.593, 0.372], [0.215, 0.174, 0.256], [0.782, 0.718, 0.787], [0.630, 0.558, 0.585], [1.684, 1.402, 1.540], [0.091, 0.075, 0.015], [1.326, 0.916, 0.187], [0.451, 0.451, 0.060], [1.477, 0.530, 0.259], [36.169, 0.410, 22.395], [0.143, 0.143, 0.140], [0.107, 0.102, 0.106], [0.139, 0.143, 0.143], [0.424, 0.395, 0.377], [4.494, 3.749, 3.708], [0.036, 0.036, 0.035], [0.411, 0.270, 0.245], [0.366, 0.354, 0.329], [2.204, 1.636, 1.617], [1.125, 1.177, 1.098], [1.052, 1.127, 1.060], [0.161, 0.189, 0.137], [0.041, 0.046, 0.042], [0.215, 0.031, 0.126], [0.121, 0.087, 0.033], [0.073, 0.072, 0.164], [0.149, 0.088, 0.021], [0.017, 0.017, 0.186], [0.098, 0.113, 0.014]
+[0.002, 0.002, 0.002], [0.013, 0.216, 0.010], [0.024, 0.200, 0.171], [0.032, 0.033, 0.393], [0.273, 0.204, 0.173], [0.397, 0.369, 0.267], [0.110, 0.060, 0.012], [0.015, 0.013, 0.013], [0.446, 0.236, 0.384], [0.369, 0.256, 0.285], [0.219, 0.123, 0.122], [0.339, 0.238, 0.133], [0.502, 0.265, 0.269], [0.405, 0.401, 0.410], [0.393, 0.295, 0.302], [0.200, 0.202, 0.178], [0.677, 0.811, 0.648], [0.527, 0.469, 0.528], [1.428, 1.151, 1.100], [0.080, 0.018, 0.009], [0.380, 1.284, 0.213], [0.425, 0.068, 0.428], [1.226, 1.174, 0.494], [0.344, 25.142, 0.365], [0.136, 0.338, 0.140], [0.103, 0.104, 0.103], [0.139, 0.137, 0.137], [0.440, 0.381, 0.381], [2.696, 2.361, 2.030], [0.148, 0.035, 0.035], [0.408, 0.268, 0.418], [0.785, 0.380, 0.376], [1.499, 1.780, 1.435], [0.982, 1.047, 1.114], [1.020, 1.043, 0.981], [0.139, 0.157, 0.158], [0.182, 0.045, 0.043], [0.028, 0.028, 0.026], [0.118, 0.027, 0.027], [0.075, 0.176, 0.073], [0.197, 0.092, 0.018], [0.102, 0.016, 0.017], [0.015, 0.016, 0.017]
]
}
diff --git a/clickhouse-cloud/results/aws.3.16.json b/clickhouse-cloud/results/aws.3.16.json
index 03d14e21d..9495334ff 100644
--- a/clickhouse-cloud/results/aws.3.16.json
+++ b/clickhouse-cloud/results/aws.3.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 219.069,
- "data_size": 9940380641,
+ "load_time": 268.230,
+ "data_size": 9946805833,
"result": [
-[0.005, 0.018, 0.002], [0.184, 0.042, 0.018], [0.227, 0.184, 0.114], [0.407, 0.393, 0.166], [0.816, 1.228, 0.777], [1.447, 1.435, 1.598], [0.112, 0.111, 0.039], [0.024, 0.151, 0.024], [1.246, 1.208, 1.125], [1.454, 1.204, 1.328], [0.440, 0.486, 0.454], [0.543, 0.501, 0.570], [1.514, 1.312, 1.247], [1.835, 2.651, 1.990], [1.855, 1.824, 1.687], [1.195, 1.171, 0.954], [4.033, 5.512, 3.968], [2.950, 4.184, 3.047], [13.120, 8.136, 16.729], [0.047, 0.136, 0.006], [3.033, 9.325, 1.063], [5.952, 3.450, 2.724], [4.115, 9.524, 1.468], [34.905, 1.889, 1.462], [0.732, 0.819, 0.887], [0.602, 0.492, 0.487], [0.730, 0.717, 0.894], [2.369, 2.378, 2.492], [31.312, 30.555, 26.169], [0.615, 0.088, 0.089], [1.302, 2.459, 1.743], [1.925, 4.138, 2.911], [11.568, 10.766, 11.708], [12.250, 10.766, 6.178], [6.293, 10.552, 6.106], [0.801, 0.864, 0.702], [0.286, 0.312, 0.078], [0.157, 0.040, 0.100], [0.130, 0.043, 0.148], [0.141, 0.143, 0.142], [0.169, 0.022, 0.022], [0.138, 0.137, 0.021], [0.132, 0.019, 0.016]
+[0.002, 0.002, 0.002], [0.260, 0.020, 0.016], [0.092, 0.234, 0.090], [0.182, 0.178, 0.181], [0.979, 0.890, 0.771], [1.406, 1.402, 1.548], [0.042, 0.042, 0.043], [0.078, 0.022, 0.022], [1.110, 1.036, 1.215], [1.522, 1.565, 1.551], [0.525, 0.396, 0.396], [0.563, 0.543, 0.596], [1.187, 1.180, 1.134], [1.851, 2.551, 2.041], [1.816, 1.536, 1.338], [1.138, 1.036, 0.818], [3.343, 3.101, 4.344], [2.070, 2.670, 2.830], [7.458, 9.887, 8.514], [0.173, 0.127, 0.006], [8.303, 3.201, 1.372], [3.462, 0.360, 0.348], [8.351, 4.142, 8.190], [38.461, 26.515, 15.424], [0.743, 0.704, 0.900], [0.471, 0.477, 0.466], [0.704, 0.709, 0.703], [2.309, 2.311, 2.293], [19.146, 14.496, 14.506], [0.223, 0.121, 0.090], [1.665, 1.280, 1.274], [2.130, 3.871, 1.742], [13.095, 10.757, 9.921], [6.076, 6.761, 5.900], [5.802, 10.033, 6.237], [0.626, 0.624, 0.676], [0.135, 0.080, 0.081], [0.199, 0.097, 0.039], [0.040, 0.041, 0.042], [0.141, 0.138, 0.139], [0.021, 0.022, 0.116], [0.022, 0.020, 0.022], [0.016, 0.016, 0.017]
]
}
diff --git a/clickhouse-cloud/results/aws.3.236.json b/clickhouse-cloud/results/aws.3.236.json
index dddca329a..dbda9c479 100644
--- a/clickhouse-cloud/results/aws.3.236.json
+++ b/clickhouse-cloud/results/aws.3.236.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 236GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 55.196,
- "data_size": 9947181162,
+ "load_time": 86.772,
+ "data_size": 9945399538,
"result": [
-[0.002, 0.002, 0.002], [0.373, 0.319, 0.068], [0.182, 0.024, 0.173], [0.222, 0.169, 0.026], [0.126, 0.111, 0.109], [0.319, 0.173, 0.160], [0.015, 0.015, 0.016], [0.100, 0.072, 0.017], [0.293, 0.490, 0.277], [0.321, 0.312, 0.421], [0.239, 0.206, 0.110], [0.233, 0.100, 0.118], [0.347, 0.154, 0.293], [0.266, 0.232, 0.237], [0.298, 0.232, 0.214], [0.127, 0.122, 0.130], [0.420, 0.443, 0.430], [0.256, 0.257, 0.251], [1.090, 0.954, 1.021], [0.062, 0.051, 0.004], [0.747, 1.154, 0.148], [0.294, 0.286, 0.050], [0.360, 0.202, 0.201], [34.107, 0.416, 22.148], [0.094, 0.090, 0.089], [0.066, 0.064, 0.067], [0.091, 0.089, 0.090], [0.283, 0.307, 0.269], [1.943, 2.473, 1.943], [0.044, 0.042, 0.041], [0.446, 0.180, 0.170], [0.253, 0.679, 0.225], [0.972, 1.246, 0.821], [0.791, 0.789, 0.801], [0.785, 0.761, 0.725], [0.495, 0.098, 0.092], [0.250, 0.042, 0.220], [0.135, 0.027, 0.029], [0.029, 0.028, 0.120], [0.327, 0.072, 0.200], [0.017, 0.153, 0.080], [0.132, 0.017, 0.017], [0.118, 0.013, 0.014]
+[0.002, 0.002, 0.002], [0.016, 0.013, 0.013], [0.349, 0.087, 0.260], [0.292, 0.026, 0.026], [0.125, 0.121, 0.225], [0.415, 0.274, 0.184], [0.014, 0.084, 0.013], [0.016, 0.014, 0.016], [0.416, 0.329, 0.296], [0.288, 0.301, 0.286], [0.241, 0.105, 0.188], [0.113, 0.111, 0.187], [0.201, 0.205, 0.174], [0.260, 0.272, 0.294], [0.314, 0.189, 0.158], [0.098, 0.092, 0.096], [0.463, 0.439, 0.393], [0.264, 0.284, 0.347], [0.878, 0.960, 0.616], [0.091, 0.004, 0.051], [0.840, 0.136, 0.660], [0.266, 0.268, 0.057], [0.753, 0.191, 0.355], [34.912, 0.394, 0.311], [0.085, 0.083, 0.081], [0.083, 0.081, 0.085], [0.085, 0.082, 0.083], [0.274, 0.271, 0.345], [1.555, 1.104, 1.098], [0.040, 0.039, 0.040], [0.331, 0.154, 0.170], [0.676, 0.239, 0.437], [1.080, 0.976, 0.756], [0.747, 0.752, 1.093], [0.953, 0.708, 0.685], [0.389, 0.065, 0.304], [0.247, 0.046, 0.042], [0.271, 0.028, 0.026], [0.125, 0.094, 0.029], [0.074, 0.068, 0.068], [0.127, 0.017, 0.090], [0.118, 0.080, 0.017], [0.013, 0.013, 0.117]
]
}
diff --git a/clickhouse-cloud/results/aws.3.32.json b/clickhouse-cloud/results/aws.3.32.json
index 00a84c19e..43f9eac90 100644
--- a/clickhouse-cloud/results/aws.3.32.json
+++ b/clickhouse-cloud/results/aws.3.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 109.124,
- "data_size": 9945232800,
+ "load_time": 257.751,
+ "data_size": 9945134736,
"result": [
-[0.002, 0.002, 0.025], [0.657, 0.061, 0.020], [0.076, 0.520, 0.208], [0.121, 0.223, 0.219], [0.497, 0.649, 0.490], [0.838, 0.887, 0.897], [0.027, 0.029, 0.093], [0.081, 0.018, 0.017], [0.623, 0.579, 0.654], [0.703, 0.680, 0.620], [0.261, 0.332, 0.357], [0.406, 0.307, 0.376], [0.762, 0.815, 0.711], [1.201, 1.071, 1.104], [1.097, 1.100, 1.071], [0.605, 0.472, 0.455], [2.258, 2.071, 2.741], [1.694, 1.746, 1.507], [4.246, 4.761, 4.793], [0.102, 0.006, 0.028], [1.397, 0.648, 4.091], [1.379, 1.597, 3.126], [1.824, 4.423, 0.778], [36.830, 0.923, 0.819], [0.434, 0.418, 0.918], [0.307, 0.297, 0.277], [0.400, 0.439, 0.395], [1.242, 1.185, 1.183], [15.532, 14.357, 14.866], [0.281, 0.142, 0.059], [1.303, 0.974, 0.688], [2.056, 0.890, 1.462], [3.993, 2.752, 2.741], [3.212, 5.721, 3.269], [3.256, 3.285, 3.250], [0.386, 0.376, 0.374], [0.049, 0.225, 0.050], [0.136, 0.130, 0.029], [0.184, 0.030, 0.081], [0.083, 0.215, 0.079], [0.138, 0.017, 0.106], [0.157, 0.017, 0.187], [0.144, 0.078, 0.016]
+[0.002, 0.003, 0.002], [0.015, 0.013, 0.305], [0.169, 0.058, 0.140], [0.388, 0.227, 0.086], [0.468, 0.479, 0.448], [0.930, 0.878, 0.646], [0.112, 0.088, 0.023], [0.017, 0.018, 0.017], [0.643, 0.498, 0.595], [0.601, 0.787, 0.705], [0.230, 0.234, 0.298], [0.352, 0.249, 0.337], [0.612, 0.650, 0.692], [1.064, 1.239, 1.073], [0.805, 0.976, 0.943], [0.657, 0.468, 0.616], [2.009, 1.796, 1.848], [1.096, 1.141, 1.108], [3.640, 3.240, 3.304], [0.117, 0.032, 0.061], [4.285, 1.235, 0.555], [1.345, 0.138, 0.137], [1.603, 4.689, 0.790], [26.100, 19.081, 0.799], [0.376, 0.378, 0.373], [0.254, 0.263, 0.257], [0.377, 0.387, 0.383], [1.225, 1.198, 1.169], [7.290, 9.201, 8.437], [0.194, 0.100, 0.062], [0.893, 0.687, 0.726], [1.837, 0.940, 0.871], [4.073, 2.726, 2.823], [3.131, 3.201, 3.376], [3.222, 3.116, 3.207], [0.449, 0.356, 0.391], [0.050, 0.048, 0.050], [0.028, 0.029, 0.030], [0.030, 0.030, 0.031], [0.082, 0.083, 0.083], [0.190, 0.062, 0.017], [0.017, 0.017, 0.017], [0.016, 0.015, 0.016]
]
}
diff --git a/clickhouse-cloud/results/aws.3.64.json b/clickhouse-cloud/results/aws.3.64.json
index c0c695ab1..8fe6e6b5a 100644
--- a/clickhouse-cloud/results/aws.3.64.json
+++ b/clickhouse-cloud/results/aws.3.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 59.040,
- "data_size": 9946816484,
+ "load_time": 222.215,
+ "data_size": 9948884314,
"result": [
-[0.002, 0.002, 0.002], [0.337, 0.302, 0.012], [0.170, 0.128, 0.116], [0.051, 0.057, 0.162], [0.247, 0.217, 0.306], [0.522, 0.372, 0.430], [0.134, 0.016, 0.066], [0.186, 0.014, 0.015], [0.457, 0.432, 0.350], [0.406, 0.399, 0.399], [0.159, 0.251, 0.226], [0.265, 0.224, 0.176], [0.465, 0.521, 0.394], [0.598, 0.549, 0.625], [0.545, 0.554, 0.613], [0.292, 0.271, 0.292], [1.124, 1.053, 1.169], [0.814, 0.837, 0.964], [2.501, 2.437, 2.379], [0.067, 0.005, 0.019], [0.707, 1.928, 0.333], [0.744, 0.781, 1.590], [2.186, 1.717, 0.916], [0.531, 30.644, 0.508], [0.474, 0.211, 0.205], [0.151, 0.153, 0.150], [0.210, 0.210, 0.223], [0.708, 0.680, 0.675], [8.046, 7.259, 6.606], [0.043, 0.043, 0.042], [0.656, 0.421, 0.418], [1.197, 0.550, 0.510], [1.578, 2.985, 2.321], [2.204, 1.888, 3.007], [1.868, 2.289, 1.841], [0.475, 0.297, 0.256], [0.049, 0.242, 0.210], [0.026, 0.159, 0.025], [0.028, 0.123, 0.029], [0.315, 0.075, 0.175], [0.143, 0.017, 0.017], [0.141, 0.017, 0.016], [0.169, 0.077, 0.014]
+[0.002, 0.002, 0.002], [0.012, 0.173, 0.011], [0.219, 0.032, 0.229], [0.412, 0.052, 0.172], [0.238, 0.220, 0.239], [0.853, 0.387, 0.488], [0.112, 0.054, 0.016], [0.015, 0.015, 0.017], [0.480, 0.361, 0.353], [0.459, 0.400, 0.402], [0.148, 0.153, 0.256], [0.260, 0.176, 0.239], [0.406, 0.360, 0.405], [0.599, 0.593, 0.571], [0.533, 0.651, 0.516], [0.484, 0.397, 0.218], [0.946, 0.987, 1.050], [0.740, 0.666, 0.611], [1.809, 2.154, 1.517], [0.098, 0.022, 0.066], [2.378, 0.308, 0.630], [0.717, 0.088, 0.739], [2.625, 0.429, 0.427], [0.506, 25.716, 16.152], [0.213, 0.212, 0.208], [0.148, 0.150, 0.150], [0.210, 0.213, 0.207], [0.618, 0.627, 0.637], [4.774, 4.291, 3.657], [0.152, 0.042, 0.042], [0.482, 0.419, 0.466], [1.035, 0.773, 0.545], [1.934, 1.955, 1.360], [1.664, 1.670, 1.658], [1.643, 1.613, 1.586], [0.183, 0.201, 0.210], [0.045, 0.047, 0.044], [0.096, 0.029, 0.028], [0.025, 0.027, 0.026], [0.071, 0.072, 0.066], [0.109, 0.067, 0.016], [0.015, 0.016, 0.017], [0.013, 0.012, 0.015]
]
}
diff --git a/clickhouse-cloud/results/aws.3.8.json b/clickhouse-cloud/results/aws.3.8.json
index 540c36371..75cb31998 100644
--- a/clickhouse-cloud/results/aws.3.8.json
+++ b/clickhouse-cloud/results/aws.3.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (aws)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "aws"],
- "load_time": 476.531,
- "data_size": 9946351549,
+ "load_time": 505.000,
+ "data_size": 9945886239,
"result": [
-[0.002, 0.002, 0.002], [0.224, 0.160, 0.027], [0.338, 0.319, 0.169], [0.946, 0.672, 0.668], [1.486, 1.546, 1.502], [2.968, 2.627, 6.236], [0.149, 0.127, 0.077], [0.049, 0.042, 0.038], [3.930, 2.510, 2.082], [4.279, 2.479, 4.700], [0.809, 1.222, 0.750], [0.963, 1.493, 1.443], [2.559, 2.843, 4.612], [4.165, 3.875, 7.514], [4.406, 7.883, 3.819], [3.241, 1.920, 2.186], [13.007, 23.094, 12.788], [16.745, 10.066, 11.276], [28.570, 26.280, 24.545], [0.179, 0.009, 0.152], [18.735, 11.138, 2.133], [6.212, 5.517, 6.038], [19.873, 12.144, 6.836], [6.136, 23.215, 2.944], [1.496, 1.503, 1.500], [1.030, 1.008, 0.983], [1.514, 1.450, 1.503], [5.227, 5.118, 5.059], [64.225, 55.203, 53.686], [0.165, 0.335, 0.205], [3.406, 3.105, 2.768], [3.977, 3.834, 7.062], [28.491, 22.055, 20.914], [21.085, 21.192, 21.247], [22.470, 21.408, 20.993], [1.362, 1.438, 1.328], [0.273, 0.148, 0.145], [0.073, 0.076, 0.068], [0.066, 0.064, 0.066], [0.289, 0.309, 0.427], [0.160, 0.034, 0.035], [0.119, 0.032, 0.099], [0.025, 0.024, 0.025]
+[0.003, 0.002, 0.002], [0.034, 0.335, 0.059], [0.392, 0.344, 0.235], [0.621, 0.604, 0.316], [1.530, 1.600, 1.545], [3.295, 2.967, 2.749], [0.125, 0.082, 0.073], [0.058, 0.044, 0.034], [2.128, 3.589, 2.197], [4.237, 2.686, 2.905], [1.140, 0.821, 1.175], [1.405, 0.953, 1.307], [4.281, 4.596, 3.848], [10.970, 6.211, 9.902], [4.628, 4.754, 4.564], [1.687, 1.748, 1.539], [12.591, 17.194, 6.977], [8.936, 8.296, 13.212], [29.719, 21.202, 19.735], [0.091, 0.601, 0.010], [4.949, 16.835, 2.243], [7.657, 5.448, 0.464], [6.385, 22.763, 12.512], [33.552, 18.906, 2.945], [1.463, 1.503, 1.465], [1.250, 1.061, 0.923], [1.485, 1.519, 1.410], [4.675, 4.577, 4.954], [30.120, 38.282, 31.175], [0.169, 0.163, 0.285], [3.818, 2.716, 2.579], [7.275, 4.378, 3.686], [20.545, 28.120, 23.537], [21.811, 20.397, 23.402], [23.155, 20.083, 21.490], [1.097, 1.005, 1.003], [0.148, 0.150, 0.287], [0.066, 0.063, 0.076], [0.066, 0.064, 0.061], [0.320, 0.269, 0.306], [0.141, 0.087, 0.037], [0.028, 0.028, 0.026], [0.024, 0.025, 0.023]
]
}
diff --git a/clickhouse-cloud/results/azure.1.12.json b/clickhouse-cloud/results/azure.1.12.json
index 9e4b14a11..b11c31612 100644
--- a/clickhouse-cloud/results/azure.1.12.json
+++ b/clickhouse-cloud/results/azure.1.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 336.387,
- "data_size": 9942318871,
+ "load_time": 340.520,
+ "data_size": 9941409521,
"result": [
-[0.003, 0.002, 0.002], [0.028, 0.025, 0.025], [0.224, 0.204, 0.199], [0.379, 0.298, 0.239], [1.598, 1.583, 1.685], [3.268, 2.961, 2.767], [0.031, 0.030, 0.029], [0.023, 0.024, 0.025], [2.512, 2.291, 2.237], [3.455, 2.410, 2.174], [0.520, 0.519, 0.545], [0.654, 0.683, 0.568], [2.111, 2.175, 2.309], [3.481, 3.535, 3.374], [3.124, 2.764, 2.991], [1.807, 1.864, 1.737], [15.827, 13.349, 8.492], [8.813, 8.261, 8.267], [22.759, 21.345, 22.062], [0.057, 0.007, 0.007], [3.877, 1.727, 1.676], [4.449, 0.383, 0.311], [4.971, 2.269, 2.336], [2.423, 2.102, 2.118], [1.143, 1.133, 1.113], [0.769, 0.776, 0.806], [1.201, 1.224, 0.923], [3.587, 3.718, 3.397], [46.660, 47.539, 45.014], [0.138, 0.121, 0.110], [2.345, 2.298, 2.267], [2.686, 2.385, 1.994], [13.546, 14.479, 14.448], [13.535, 14.914, 14.404], [13.476, 12.882, 13.482], [1.001, 1.032, 0.884], [0.102, 0.108, 0.099], [0.046, 0.052, 0.040], [0.038, 0.044, 0.040], [0.202, 0.178, 0.180], [0.026, 0.024, 0.025], [0.019, 0.018, 0.017], [0.019, 0.017, 0.014]
+[0.066, 0.006, 0.030], [0.045, 0.017, 0.061], [0.230, 0.319, 0.222], [0.429, 0.406, 0.410], [2.751, 2.193, 1.863], [3.072, 2.706, 2.436], [0.030, 0.028, 0.027], [0.021, 0.022, 0.020], [2.069, 1.796, 1.780], [2.225, 2.134, 2.419], [0.528, 0.534, 0.550], [0.626, 0.635, 0.562], [2.061, 2.609, 2.077], [3.475, 4.121, 3.889], [3.146, 2.853, 2.804], [1.760, 1.457, 1.610], [13.048, 6.995, 10.229], [3.862, 7.689, 7.477], [20.030, 19.877, 20.448], [0.063, 0.007, 0.007], [4.002, 1.755, 1.771], [4.983, 0.405, 0.404], [5.646, 2.496, 2.479], [2.325, 2.252, 2.207], [0.938, 1.099, 1.139], [0.738, 0.787, 0.766], [1.107, 1.062, 0.999], [3.851, 3.796, 3.506], [23.358, 23.563, 24.333], [0.104, 0.116, 0.107], [2.668, 2.303, 2.333], [3.850, 2.932, 2.652], [21.624, 21.410, 22.698], [14.979, 14.373, 14.312], [13.626, 13.746, 14.675], [0.962, 0.774, 0.799], [0.101, 0.103, 0.098], [0.049, 0.042, 0.045], [0.042, 0.040, 0.038], [0.202, 0.198, 0.176], [0.024, 0.023, 0.023], [0.018, 0.017, 0.018], [0.015, 0.016, 0.013]
]
}
diff --git a/clickhouse-cloud/results/azure.1.8.json b/clickhouse-cloud/results/azure.1.8.json
index 3f762b577..cff2e0969 100644
--- a/clickhouse-cloud/results/azure.1.8.json
+++ b/clickhouse-cloud/results/azure.1.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 637.866,
- "data_size": 9947491120,
+ "load_time": 537.939,
+ "data_size": 9946983717,
"result": [
-[0.003, 0.002, 0.002], [0.069, 0.073, 0.022], [0.344, 0.381, 0.403], [0.782, 0.523, 0.592], [3.175, 3.277, 3.092], [4.753, 4.382, 4.132], [0.044, 0.045, 0.046], [0.033, 0.029, 0.030], [3.704, 3.800, 3.337], [4.013, 4.804, 4.607], [1.071, 0.956, 0.740], [1.120, 1.013, 1.260], [4.280, 4.133, 4.368], [7.257, 12.797, 6.685], [6.753, 6.387, 5.700], [3.403, 3.302, 3.682], [23.530, 21.901, 15.839], [12.543, 11.669, 11.708], [34.306, 32.809, 31.370], [0.089, 0.010, 0.008], [4.946, 1.970, 1.912], [5.360, 0.447, 0.486], [6.667, 3.159, 2.692], [2.581, 2.481, 2.500], [1.332, 1.291, 1.286], [0.938, 0.920, 0.907], [1.358, 1.310, 1.276], [4.977, 4.508, 4.649], [51.330, 48.769, 48.890], [0.166, 0.156, 0.144], [2.581, 2.459, 2.555], [3.503, 3.574, 3.522], [24.452, 24.944, 26.063], [23.922, 24.954, 23.756], [23.763, 23.530, 23.584], [1.485, 1.440, 1.497], [0.161, 0.133, 0.145], [0.067, 0.065, 0.058], [0.057, 0.075, 0.057], [0.302, 0.273, 0.295], [0.030, 0.027, 0.026], [0.022, 0.022, 0.026], [0.022, 0.018, 0.019]
+[0.003, 0.002, 0.002], [0.023, 0.018, 0.020], [0.342, 0.293, 0.349], [0.530, 0.459, 0.452], [2.818, 2.704, 3.182], [6.322, 5.408, 5.655], [0.086, 0.094, 0.052], [0.090, 0.033, 0.026], [4.882, 4.698, 4.242], [4.920, 5.412, 5.253], [1.252, 1.338, 1.206], [1.516, 1.325, 1.223], [5.456, 5.297, 4.573], [6.752, 5.785, 9.868], [4.685, 4.315, 4.709], [2.996, 2.776, 2.482], [16.838, 17.711, 16.704], [7.334, 11.641, 12.108], [30.274, 29.384, 25.073], [0.111, 0.010, 0.009], [5.046, 1.917, 1.906], [5.108, 0.415, 0.399], [6.046, 2.613, 2.743], [2.625, 2.556, 2.540], [1.293, 1.241, 1.266], [0.880, 0.879, 0.900], [1.274, 1.284, 1.304], [4.284, 4.541, 4.380], [27.478, 26.709, 26.609], [0.151, 0.143, 0.140], [2.583, 2.474, 2.502], [3.490, 3.263, 3.203], [23.634, 26.498, 25.775], [21.952, 23.152, 21.221], [20.967, 20.446, 21.433], [1.118, 1.104, 1.117], [0.148, 0.141, 0.176], [0.084, 0.060, 0.061], [0.061, 0.057, 0.071], [0.279, 0.278, 0.287], [0.031, 0.027, 0.025], [0.020, 0.019, 0.022], [0.022, 0.016, 0.015]
]
}
diff --git a/clickhouse-cloud/results/azure.2.12.json b/clickhouse-cloud/results/azure.2.12.json
index ee02ac7a0..63a4cbc7a 100644
--- a/clickhouse-cloud/results/azure.2.12.json
+++ b/clickhouse-cloud/results/azure.2.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 340.687,
- "data_size": 9940842756,
+ "load_time": 321.120,
+ "data_size": 9940835556,
"result": [
-[0.003, 0.005, 0.002], [0.027, 1.164, 0.028], [0.390, 0.110, 0.148], [1.335, 0.182, 0.303], [1.609, 1.280, 1.204], [3.115, 2.970, 3.461], [0.093, 0.032, 0.039], [0.181, 0.026, 0.068], [1.870, 1.650, 1.611], [2.195, 1.979, 2.301], [0.486, 0.507, 0.477], [0.577, 0.604, 0.556], [2.095, 2.714, 2.115], [3.037, 3.342, 2.433], [2.882, 3.465, 3.659], [2.113, 1.733, 1.505], [14.074, 11.037, 14.365], [6.579, 9.637, 10.213], [29.392, 19.233, 31.548], [0.063, 0.007, 0.054], [4.517, 1.963, 1.950], [4.602, 3.278, 0.278], [5.981, 2.695, 3.779], [2.671, 3.541, 2.385], [0.818, 0.826, 0.836], [0.880, 0.570, 0.881], [0.821, 1.358, 0.850], [2.776, 3.927, 2.783], [49.782, 46.848, 46.188], [0.450, 0.121, 0.134], [2.280, 1.753, 4.812], [15.231, 3.114, 2.262], [20.424, 20.297, 19.476], [17.132, 43.294, 15.999], [15.601, 13.856, 13.282], [1.128, 1.098, 1.095], [0.101, 0.093, 0.092], [0.053, 0.066, 0.043], [0.043, 0.039, 0.037], [0.263, 0.183, 0.171], [0.021, 0.027, 0.020], [0.016, 0.019, 0.015], [0.016, 0.016, 0.017]
+[0.003, 0.024, 0.002], [0.278, 0.019, 0.030], [0.510, 0.154, 0.206], [0.573, 0.495, 0.189], [1.313, 1.532, 1.216], [2.354, 3.155, 3.003], [0.038, 0.032, 0.032], [0.035, 0.027, 0.021], [1.766, 1.576, 1.582], [3.024, 3.022, 2.376], [1.738, 0.467, 0.483], [0.616, 0.615, 0.622], [2.096, 2.108, 2.651], [3.067, 3.307, 3.501], [2.251, 2.438, 1.982], [1.549, 1.354, 1.333], [12.348, 7.905, 10.986], [4.130, 8.159, 8.062], [21.115, 20.063, 13.160], [0.066, 0.061, 0.006], [4.335, 1.872, 1.740], [4.606, 0.375, 3.678], [5.779, 3.952, 1.722], [2.530, 3.329, 2.265], [0.823, 1.181, 1.214], [0.748, 0.595, 0.832], [0.884, 0.855, 1.160], [2.849, 2.806, 2.830], [17.385, 16.941, 27.548], [0.119, 0.107, 0.105], [2.870, 1.690, 2.487], [3.905, 2.317, 3.262], [16.236, 15.895, 14.992], [16.349, 14.982, 32.851], [8.844, 17.436, 17.244], [1.010, 0.910, 0.909], [0.135, 0.099, 0.097], [0.045, 0.047, 0.044], [0.056, 0.047, 0.040], [0.218, 0.211, 0.211], [0.025, 0.023, 0.024], [0.110, 0.021, 0.019], [0.017, 0.014, 0.016]
]
}
diff --git a/clickhouse-cloud/results/azure.2.120.json b/clickhouse-cloud/results/azure.2.120.json
index 7ba739ea4..d740b2866 100644
--- a/clickhouse-cloud/results/azure.2.120.json
+++ b/clickhouse-cloud/results/azure.2.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 103.423,
- "data_size": 9949842171,
+ "load_time": 118.325,
+ "data_size": 9950116877,
"result": [
-[0.002, 0.002, 0.002], [0.016, 5.204, 0.024], [0.027, 0.955, 0.032], [1.222, 0.405, 0.035], [0.236, 0.334, 0.228], [0.288, 5.627, 0.276], [0.011, 0.061, 0.011], [0.014, 0.017, 0.052], [0.296, 0.396, 0.310], [0.313, 0.342, 0.358], [0.219, 0.144, 0.140], [0.188, 0.142, 0.144], [0.353, 0.314, 0.300], [0.453, 0.613, 0.426], [0.376, 0.359, 0.351], [0.291, 0.288, 0.244], [0.920, 0.903, 0.918], [0.751, 0.639, 0.647], [1.768, 7.161, 2.032], [0.065, 0.018, 0.005], [8.344, 0.431, 0.226], [0.532, 0.501, 0.075], [0.589, 6.309, 0.332], [0.396, 0.381, 0.372], [0.173, 0.144, 0.160], [0.111, 0.115, 0.129], [0.175, 0.158, 0.161], [0.455, 0.457, 0.526], [4.359, 4.470, 10.058], [0.036, 0.036, 0.190], [0.477, 0.310, 0.338], [6.590, 0.456, 0.446], [1.954, 2.106, 1.737], [1.547, 1.319, 1.442], [1.339, 1.301, 1.253], [0.212, 0.252, 0.194], [0.046, 0.051, 0.064], [0.028, 0.030, 0.028], [0.030, 0.028, 0.037], [0.072, 0.079, 0.079], [0.017, 0.017, 0.021], [0.017, 0.017, 0.018], [0.013, 0.012, 0.013]
+[0.002, 0.002, 0.002], [0.250, 0.013, 0.011], [0.424, 0.030, 0.031], [0.406, 0.036, 0.042], [0.391, 0.248, 0.224], [0.277, 0.714, 0.279], [0.013, 0.119, 0.011], [0.013, 0.013, 0.029], [0.487, 0.291, 0.296], [0.333, 0.341, 0.310], [0.182, 0.147, 0.145], [0.141, 0.139, 0.195], [0.336, 0.318, 0.356], [0.481, 0.440, 0.445], [0.322, 0.326, 0.442], [0.229, 0.221, 0.225], [0.943, 0.894, 0.860], [0.554, 0.579, 0.524], [2.314, 1.696, 1.647], [0.039, 0.018, 0.008], [0.425, 0.231, 0.205], [3.230, 0.099, 0.077], [0.559, 0.326, 2.145], [0.392, 20.780, 0.501], [0.166, 0.140, 0.147], [0.111, 0.143, 0.109], [0.165, 0.162, 0.161], [0.494, 0.473, 0.433], [4.028, 3.037, 2.592], [0.034, 0.035, 0.037], [0.446, 0.395, 0.348], [1.545, 0.448, 0.430], [2.238, 1.653, 1.685], [1.460, 1.429, 1.552], [1.644, 1.620, 1.413], [0.211, 0.164, 0.160], [0.049, 0.042, 0.050], [0.025, 0.034, 0.034], [0.026, 0.025, 0.027], [0.071, 0.064, 0.064], [0.015, 0.018, 0.024], [0.019, 0.016, 0.016], [0.013, 0.013, 0.011]
]
}
diff --git a/clickhouse-cloud/results/azure.2.16.json b/clickhouse-cloud/results/azure.2.16.json
index 08b4956b0..f4ddab429 100644
--- a/clickhouse-cloud/results/azure.2.16.json
+++ b/clickhouse-cloud/results/azure.2.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 261.491,
- "data_size": 9941460074,
+ "load_time": 244.212,
+ "data_size": 9942030788,
"result": [
-[0.002, 0.002, 0.002], [0.027, 0.594, 0.027], [0.452, 0.137, 0.122], [1.432, 0.241, 0.150], [0.953, 1.369, 1.236], [2.040, 1.677, 1.588], [0.035, 0.117, 0.022], [0.046, 0.022, 0.019], [1.323, 1.294, 1.397], [1.589, 1.553, 1.451], [1.948, 0.362, 0.371], [0.453, 0.413, 0.470], [2.606, 2.123, 1.534], [2.609, 2.790, 2.263], [2.295, 2.083, 1.959], [1.495, 1.236, 1.498], [6.136, 6.089, 6.196], [3.759, 4.001, 3.428], [11.740, 10.751, 15.442], [0.055, 0.006, 0.006], [7.405, 2.817, 1.146], [2.996, 0.245, 0.237], [4.167, 1.596, 3.810], [1.871, 1.322, 1.671], [0.659, 0.641, 0.641], [0.618, 0.556, 0.567], [0.664, 0.729, 0.844], [2.097, 2.912, 2.763], [28.983, 29.753, 24.931], [0.081, 0.085, 0.079], [1.845, 1.184, 1.170], [1.749, 2.724, 1.484], [17.430, 11.545, 15.666], [8.656, 7.092, 25.380], [8.082, 6.711, 8.323], [1.021, 0.932, 0.761], [0.143, 0.088, 0.084], [0.037, 0.241, 0.046], [0.042, 0.043, 0.050], [0.252, 0.153, 0.170], [0.264, 0.026, 0.021], [0.017, 0.110, 0.020], [0.017, 0.019, 0.017]
+[0.002, 0.002, 0.002], [0.022, 0.197, 0.016], [0.314, 0.090, 0.092], [0.295, 0.868, 0.154], [0.977, 1.508, 0.932], [1.881, 1.443, 1.444], [0.029, 0.026, 0.027], [0.018, 0.029, 0.023], [1.329, 1.275, 1.413], [1.774, 1.609, 1.490], [0.392, 0.378, 0.411], [0.449, 0.463, 0.486], [1.712, 1.629, 1.626], [2.354, 2.408, 2.404], [1.857, 1.910, 1.843], [1.257, 1.201, 1.455], [4.884, 4.456, 4.323], [2.391, 3.088, 2.868], [14.886, 9.236, 16.008], [0.060, 0.007, 0.006], [3.041, 1.287, 1.326], [3.346, 0.329, 5.526], [4.021, 1.864, 4.573], [1.793, 1.713, 2.880], [0.716, 0.843, 0.652], [0.476, 0.599, 0.465], [0.664, 0.782, 0.657], [2.675, 2.829, 2.313], [13.816, 13.705, 13.857], [0.100, 0.092, 0.095], [1.309, 1.668, 1.279], [6.939, 2.181, 2.320], [14.301, 17.098, 13.245], [6.930, 11.897, 19.496], [6.469, 7.350, 6.145], [0.804, 0.926, 0.600], [0.126, 0.108, 0.085], [0.047, 0.101, 0.064], [0.056, 0.043, 0.041], [0.178, 0.222, 0.217], [0.095, 0.024, 0.023], [0.107, 0.020, 0.019], [0.017, 0.015, 0.014]
]
}
diff --git a/clickhouse-cloud/results/azure.2.32.json b/clickhouse-cloud/results/azure.2.32.json
index 359c1f154..6836aa85a 100644
--- a/clickhouse-cloud/results/azure.2.32.json
+++ b/clickhouse-cloud/results/azure.2.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 119.682,
- "data_size": 9949037675,
+ "load_time": 170.573,
+ "data_size": 9947764823,
"result": [
-[0.002, 0.002, 0.002], [0.025, 0.021, 0.014], [0.998, 0.073, 0.063], [1.023, 0.117, 0.179], [0.791, 0.564, 0.530], [0.921, 1.427, 0.806], [0.056, 0.023, 0.020], [0.048, 0.019, 0.015], [0.970, 0.633, 0.698], [0.764, 0.782, 0.989], [0.261, 0.170, 0.188], [0.302, 0.233, 0.250], [0.757, 0.800, 0.685], [1.122, 1.099, 1.035], [0.951, 1.171, 1.122], [0.815, 0.853, 0.675], [2.743, 2.953, 2.545], [1.735, 1.636, 1.826], [4.837, 5.308, 5.129], [0.070, 0.005, 0.006], [8.909, 0.601, 1.254], [1.388, 1.447, 0.156], [1.714, 5.187, 0.829], [0.814, 0.850, 0.821], [0.404, 0.413, 0.407], [0.265, 0.263, 0.307], [0.371, 0.404, 0.366], [1.205, 1.144, 1.167], [16.842, 14.874, 13.161], [0.248, 0.059, 0.065], [0.738, 0.678, 0.694], [1.911, 1.144, 0.925], [4.854, 3.352, 3.760], [3.232, 3.346, 3.636], [3.282, 3.693, 3.384], [0.530, 0.468, 0.491], [0.070, 0.056, 0.057], [0.029, 0.030, 0.036], [0.033, 0.033, 0.037], [0.104, 0.109, 0.108], [0.017, 0.018, 0.020], [0.018, 0.019, 0.016], [0.012, 0.013, 0.014]
+[0.004, 0.002, 0.003], [0.114, 0.015, 0.012], [0.328, 0.066, 0.050], [0.497, 0.071, 0.088], [0.743, 0.570, 0.511], [0.820, 0.808, 0.778], [0.016, 0.017, 0.015], [0.022, 0.015, 0.022], [1.075, 0.675, 0.903], [0.750, 1.040, 0.964], [0.315, 0.270, 0.205], [0.377, 0.315, 0.332], [1.502, 1.114, 1.084], [1.082, 1.959, 1.130], [1.518, 1.332, 0.895], [0.679, 0.963, 0.694], [3.850, 2.219, 1.887], [1.367, 1.897, 1.789], [4.046, 7.436, 6.819], [0.029, 0.057, 0.008], [1.326, 0.590, 6.034], [1.799, 1.322, 0.200], [1.699, 3.803, 1.026], [0.861, 0.839, 0.714], [0.375, 0.483, 0.367], [0.337, 0.319, 0.325], [0.369, 0.384, 0.377], [1.241, 1.648, 1.793], [7.604, 9.815, 7.707], [0.068, 0.079, 0.079], [0.743, 0.748, 0.737], [1.064, 0.946, 1.478], [4.629, 8.387, 3.798], [3.544, 5.119, 5.465], [3.499, 3.882, 5.233], [0.412, 0.546, 0.595], [0.080, 0.077, 0.057], [0.033, 0.050, 0.047], [0.033, 0.035, 0.030], [0.105, 0.150, 0.103], [0.018, 0.016, 0.028], [0.016, 0.015, 0.017], [0.020, 0.012, 0.020]
]
}
diff --git a/clickhouse-cloud/results/azure.2.64.json b/clickhouse-cloud/results/azure.2.64.json
index eaf8f9a80..0258847a6 100644
--- a/clickhouse-cloud/results/azure.2.64.json
+++ b/clickhouse-cloud/results/azure.2.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-08",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 114.282,
- "data_size": 9948906386,
+ "load_time": 138.445,
+ "data_size": 9949181345,
"result": [
-[0.002, 0.002, 0.002], [0.211, 0.019, 0.023], [0.324, 0.043, 0.194], [0.062, 0.553, 0.053], [0.358, 0.334, 0.373], [0.520, 0.962, 0.452], [0.276, 0.015, 0.014], [0.017, 0.018, 0.059], [0.694, 0.424, 0.402], [0.527, 0.527, 0.487], [0.339, 0.179, 0.162], [0.176, 0.182, 0.238], [0.653, 0.487, 0.445], [1.004, 0.699, 0.709], [0.729, 0.677, 0.622], [0.349, 0.306, 0.327], [1.283, 1.493, 1.456], [0.907, 0.950, 1.136], [3.820, 2.794, 2.937], [0.067, 0.006, 0.006], [0.665, 0.334, 4.786], [1.765, 0.741, 0.093], [0.863, 3.407, 0.485], [20.249, 0.557, 0.525], [0.233, 0.230, 0.225], [0.172, 0.167, 0.166], [0.229, 0.262, 0.210], [0.711, 0.650, 0.651], [7.541, 8.028, 7.773], [0.078, 0.053, 0.041], [0.743, 0.425, 0.473], [0.689, 0.523, 2.267], [2.073, 2.462, 2.110], [1.973, 2.338, 2.097], [2.055, 1.955, 2.415], [0.268, 0.263, 0.301], [0.043, 0.048, 0.076], [0.037, 0.031, 0.032], [0.028, 0.028, 0.027], [0.089, 0.088, 0.083], [0.027, 0.029, 0.027], [0.020, 0.018, 0.017], [0.016, 0.013, 0.015]
+[0.002, 0.002, 0.002], [0.012, 0.114, 0.014], [0.236, 0.031, 0.041], [0.047, 0.046, 0.045], [0.268, 0.246, 0.236], [0.929, 0.539, 0.484], [0.105, 0.011, 0.012], [0.014, 0.015, 0.013], [0.366, 0.352, 0.632], [0.397, 0.426, 0.395], [0.164, 0.212, 0.164], [0.224, 0.176, 0.169], [0.434, 0.443, 0.396], [0.642, 0.610, 0.641], [0.488, 0.580, 0.486], [0.259, 0.313, 0.260], [1.126, 1.121, 1.030], [0.638, 0.725, 0.582], [2.149, 2.432, 1.837], [0.020, 0.043, 0.004], [0.596, 3.788, 0.330], [0.710, 0.097, 0.688], [2.452, 0.815, 0.440], [14.155, 0.482, 0.454], [0.210, 0.213, 0.209], [0.131, 0.161, 0.165], [0.220, 0.194, 0.221], [0.618, 0.612, 0.624], [5.132, 4.163, 3.525], [0.045, 0.047, 0.040], [0.422, 0.433, 0.378], [0.554, 1.108, 0.534], [2.093, 1.911, 1.908], [1.728, 1.752, 1.757], [1.841, 1.773, 1.825], [0.240, 0.191, 0.207], [0.043, 0.038, 0.039], [0.024, 0.024, 0.033], [0.028, 0.025, 0.027], [0.077, 0.101, 0.076], [0.018, 0.016, 0.017], [0.023, 0.015, 0.016], [0.012, 0.012, 0.010]
]
}
diff --git a/clickhouse-cloud/results/azure.2.8.json b/clickhouse-cloud/results/azure.2.8.json
index 5ba48f56e..25fe1069f 100644
--- a/clickhouse-cloud/results/azure.2.8.json
+++ b/clickhouse-cloud/results/azure.2.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 773.632,
- "data_size": 9943107896,
+ "load_time": 712.998,
+ "data_size": 9943140482,
"result": [
-[0.003, 0.004, 0.003], [0.194, 0.095, 0.027], [0.511, 0.397, 0.706], [0.777, 0.411, 0.375], [6.080, 2.219, 2.168], [8.098, 2.972, 8.619], [0.107, 0.077, 0.043], [0.046, 0.042, 0.028], [8.404, 2.232, 2.290], [9.465, 3.214, 3.038], [0.659, 0.668, 2.084], [0.794, 2.312, 0.857], [9.614, 9.335, 2.695], [15.681, 22.825, 12.811], [9.757, 6.303, 5.346], [6.471, 7.074, 6.299], [35.596, 32.184, 15.943], [11.440, 17.528, 18.870], [43.285, 43.121, 42.337], [0.097, 0.015, 0.131], [10.303, 3.021, 3.196], [7.438, 0.557, 0.589], [8.815, 6.911, 2.853], [6.978, 2.845, 2.616], [1.495, 1.692, 1.605], [0.942, 1.075, 0.939], [2.094, 1.786, 1.365], [4.647, 6.007, 4.595], [68.024, 67.897, 52.971], [0.214, 0.202, 0.180], [2.847, 2.777, 2.579], [3.762, 3.788, 7.249], [28.151, 25.537, 53.371], [35.585, 24.017, 35.645], [34.680, 33.338, 31.862], [1.596, 2.667, 1.476], [0.226, 0.180, 0.163], [0.136, 0.085, 0.082], [0.083, 0.081, 0.073], [0.437, 0.305, 0.409], [0.031, 0.050, 0.030], [0.021, 0.033, 0.032], [0.026, 0.018, 0.027]
+[0.004, 0.002, 0.003], [0.516, 0.129, 0.052], [0.160, 0.488, 0.329], [0.426, 0.240, 1.261], [1.819, 6.338, 5.745], [6.916, 5.953, 3.555], [0.080, 0.048, 0.042], [0.036, 0.037, 0.036], [2.895, 2.379, 6.217], [2.463, 2.506, 6.455], [0.575, 0.555, 1.392], [1.522, 0.688, 1.621], [2.287, 8.085, 2.891], [3.772, 6.549, 3.627], [2.917, 2.958, 9.571], [1.881, 4.771, 4.744], [10.615, 21.062, 28.466], [22.588, 21.088, 7.792], [54.921, 54.714, 22.868], [0.085, 0.008, 0.008], [5.129, 10.412, 3.716], [5.124, 0.432, 0.449], [6.216, 2.887, 2.611], [2.684, 2.595, 2.547], [2.849, 2.932, 3.108], [2.044, 1.959, 0.930], [1.346, 1.292, 2.390], [7.553, 32.973, 6.266], [39.078, 40.628, 37.614], [0.144, 0.143, 0.144], [5.012, 2.693, 2.586], [3.753, 3.148, 2.918], [51.602, 47.284, 23.459], [31.744, 20.846, 32.404], [32.314, 20.333, 19.661], [1.828, 1.119, 1.630], [0.229, 0.144, 0.214], [0.061, 0.077, 0.104], [0.076, 0.075, 0.056], [0.270, 0.460, 0.289], [0.044, 0.038, 0.037], [0.022, 0.020, 0.023], [0.027, 0.023, 0.019]
]
}
diff --git a/clickhouse-cloud/results/azure.3.12.json b/clickhouse-cloud/results/azure.3.12.json
index 4a7ab3798..eb83bf346 100644
--- a/clickhouse-cloud/results/azure.3.12.json
+++ b/clickhouse-cloud/results/azure.3.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 453.354,
- "data_size": 9946513248,
+ "load_time": 381.305,
+ "data_size": 9942906205,
"result": [
-[0.008, 0.003, 0.002], [0.339, 0.022, 0.021], [6.040, 0.439, 0.367], [0.769, 1.364, 0.228], [1.552, 2.868, 3.033], [4.775, 5.989, 4.597], [0.111, 0.028, 0.085], [0.040, 0.032, 0.034], [2.275, 2.058, 3.126], [2.281, 2.611, 5.225], [1.230, 0.552, 2.100], [1.007, 0.645, 1.208], [2.204, 1.835, 2.107], [4.203, 8.219, 3.744], [6.243, 3.138, 2.760], [3.715, 1.683, 2.223], [16.545, 8.131, 15.982], [5.393, 4.559, 7.464], [22.402, 21.156, 40.545], [0.075, 0.008, 0.010], [3.163, 3.528, 6.426], [3.244, 7.164, 0.580], [4.064, 1.920, 1.868], [1.986, 1.864, 1.761], [1.956, 0.927, 2.092], [0.620, 1.116, 1.100], [0.899, 1.629, 1.753], [2.831, 5.788, 3.098], [63.948, 46.051, 44.624], [0.162, 0.119, 0.109], [2.181, 2.126, 5.134], [4.831, 15.763, 3.241], [23.589, 15.417, 21.900], [15.862, 14.723, 14.231], [23.738, 14.114, 15.007], [2.016, 1.146, 1.033], [0.114, 0.190, 0.099], [0.075, 0.059, 0.054], [0.044, 0.062, 0.066], [0.201, 0.180, 0.229], [0.036, 0.039, 0.029], [0.018, 0.017, 0.018], [0.025, 0.019, 0.020]
+[0.002, 0.003, 0.002], [0.417, 0.200, 0.021], [0.132, 0.107, 0.111], [0.262, 0.487, 0.596], [1.378, 1.287, 2.087], [2.358, 2.286, 3.724], [0.041, 0.043, 0.035], [0.036, 0.542, 0.019], [1.759, 2.907, 1.575], [3.489, 1.562, 1.669], [0.783, 0.842, 0.891], [2.467, 1.550, 0.532], [4.244, 2.185, 2.082], [7.098, 2.660, 6.766], [2.248, 3.988, 2.335], [1.554, 1.538, 2.195], [5.279, 9.821, 14.261], [5.219, 3.769, 5.974], [14.460, 24.818, 23.316], [0.064, 0.052, 0.086], [2.937, 3.202, 1.220], [3.372, 0.306, 3.121], [4.373, 7.097, 1.922], [5.728, 1.611, 1.820], [1.314, 0.907, 0.839], [0.920, 0.554, 0.557], [0.883, 1.336, 0.830], [4.625, 2.768, 4.707], [18.563, 19.391, 30.082], [0.136, 0.115, 0.117], [4.121, 2.056, 2.498], [10.213, 2.694, 3.576], [18.637, 17.059, 23.676], [18.110, 13.761, 11.155], [16.424, 15.302, 13.880], [0.892, 0.768, 0.694], [0.142, 0.094, 0.093], [0.062, 0.056, 0.062], [0.037, 0.046, 0.035], [0.185, 0.225, 0.251], [0.036, 0.025, 0.029], [0.022, 0.030, 0.027], [0.023, 0.018, 0.018]
]
}
diff --git a/clickhouse-cloud/results/azure.3.120.json b/clickhouse-cloud/results/azure.3.120.json
index 76a90ce68..9968df2f4 100644
--- a/clickhouse-cloud/results/azure.3.120.json
+++ b/clickhouse-cloud/results/azure.3.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 116.139,
- "data_size": 9951013990,
+ "load_time": 74.211,
+ "data_size": 9951026282,
"result": [
-[0.002, 0.002, 0.002], [5.164, 0.017, 0.054], [0.314, 5.281, 0.105], [5.344, 5.374, 0.036], [0.443, 0.218, 0.259], [5.414, 0.285, 5.331], [0.014, 0.132, 0.131], [0.016, 0.014, 0.058], [0.300, 0.262, 0.265], [0.549, 0.321, 0.361], [0.410, 0.175, 0.137], [0.145, 0.148, 0.263], [0.363, 0.533, 0.476], [0.543, 1.563, 0.439], [0.517, 0.409, 0.416], [0.291, 0.252, 0.270], [0.957, 0.913, 0.978], [0.650, 0.686, 0.662], [1.828, 6.037, 1.700], [0.074, 0.019, 0.047], [10.458, 0.398, 0.234], [0.500, 0.085, 7.424], [0.546, 6.596, 0.325], [24.902, 20.389, 0.387], [0.157, 0.149, 0.160], [0.127, 0.113, 0.111], [0.158, 0.150, 0.135], [0.427, 0.489, 0.406], [4.524, 6.678, 4.301], [0.035, 0.040, 0.036], [0.275, 0.280, 0.277], [1.011, 0.440, 0.374], [2.181, 2.252, 1.470], [1.395, 1.323, 1.298], [1.222, 1.336, 1.432], [0.231, 0.175, 0.245], [0.051, 0.044, 0.045], [0.034, 0.029, 0.030], [0.033, 0.031, 0.034], [0.086, 0.101, 0.078], [0.017, 0.025, 0.018], [0.017, 0.018, 0.017], [0.013, 0.014, 0.013]
+[0.002, 0.003, 0.002], [0.018, 0.017, 0.403], [0.195, 0.033, 0.029], [0.528, 0.721, 0.113], [0.288, 0.252, 0.381], [0.350, 0.873, 0.313], [0.105, 0.099, 0.012], [0.015, 0.051, 0.015], [0.487, 0.406, 0.279], [0.335, 0.510, 0.323], [0.144, 0.227, 0.143], [0.146, 0.219, 0.206], [0.692, 0.425, 0.620], [0.506, 0.602, 0.431], [0.323, 0.310, 0.612], [0.242, 0.187, 0.262], [0.759, 0.848, 1.322], [0.511, 0.536, 0.763], [1.957, 1.724, 2.489], [0.019, 0.187, 0.262], [2.584, 0.293, 0.411], [0.485, 0.709, 2.502], [2.181, 2.281, 0.562], [0.426, 24.538, 0.556], [0.390, 0.144, 0.148], [0.113, 0.287, 0.110], [0.193, 0.210, 0.148], [0.436, 0.402, 0.615], [4.570, 3.584, 2.423], [0.280, 0.034, 0.033], [0.280, 0.485, 0.264], [2.012, 2.082, 0.435], [2.170, 2.040, 2.859], [1.669, 1.764, 1.317], [1.697, 1.654, 1.257], [0.177, 0.199, 0.128], [0.074, 0.046, 0.047], [0.026, 0.070, 0.026], [0.042, 0.025, 0.048], [0.122, 0.131, 0.068], [0.082, 0.018, 0.016], [0.108, 0.085, 0.014], [0.011, 0.010, 0.022]
]
}
diff --git a/clickhouse-cloud/results/azure.3.16.json b/clickhouse-cloud/results/azure.3.16.json
index 6ae376dc7..ad2942e82 100644
--- a/clickhouse-cloud/results/azure.3.16.json
+++ b/clickhouse-cloud/results/azure.3.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-08",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 327.282,
- "data_size": 9941159518,
+ "load_time": 247.368,
+ "data_size": 9940607795,
"result": [
-[0.003, 0.027, 0.002], [0.029, 5.111, 0.017], [5.216, 0.150, 0.322], [0.259, 0.819, 5.314], [0.902, 0.961, 1.075], [1.915, 2.488, 2.222], [0.053, 0.025, 0.027], [0.087, 0.027, 0.017], [2.005, 1.239, 2.058], [2.486, 2.661, 1.406], [0.467, 0.365, 0.364], [0.380, 0.580, 0.574], [2.723, 2.366, 5.590], [6.570, 2.241, 1.930], [1.725, 3.988, 1.859], [2.728, 1.249, 1.457], [12.268, 5.135, 10.377], [5.675, 3.509, 3.132], [31.680, 22.943, 9.057], [0.045, 0.073, 0.059], [2.253, 1.016, 5.350], [2.498, 2.926, 0.248], [2.983, 5.018, 1.302], [1.304, 1.241, 1.268], [0.687, 0.638, 0.977], [0.457, 0.508, 0.667], [1.033, 1.000, 1.069], [2.201, 3.480, 2.120], [23.299, 23.193, 41.374], [0.086, 0.104, 0.089], [1.222, 2.451, 2.525], [1.883, 4.641, 1.613], [11.213, 14.535, 11.222], [6.269, 6.882, 30.627], [24.748, 11.525, 7.184], [1.049, 1.588, 0.924], [0.130, 0.139, 0.104], [0.183, 0.052, 0.047], [0.040, 0.054, 0.049], [0.219, 0.286, 0.260], [0.028, 0.096, 0.185], [0.117, 0.107, 0.016], [0.014, 0.014, 0.013]
+[0.002, 0.002, 0.038], [0.028, 0.205, 0.036], [0.118, 0.283, 0.104], [0.331, 0.302, 0.227], [1.543, 1.528, 0.921], [2.970, 2.101, 1.656], [0.053, 0.026, 0.024], [0.020, 0.018, 0.041], [1.748, 1.587, 1.774], [1.389, 1.687, 1.896], [0.382, 0.316, 0.403], [0.822, 0.495, 0.472], [1.675, 1.296, 1.612], [2.473, 2.812, 2.529], [1.942, 1.504, 1.877], [1.149, 1.137, 0.888], [4.939, 4.521, 4.102], [3.112, 2.670, 2.650], [9.358, 8.828, 13.325], [0.066, 0.046, 0.006], [3.339, 9.151, 1.322], [2.970, 0.243, 8.885], [4.122, 5.971, 5.261], [3.982, 1.503, 1.497], [0.774, 0.810, 0.726], [0.515, 0.507, 0.649], [0.658, 0.650, 0.628], [2.085, 3.067, 2.252], [14.222, 14.933, 14.485], [0.104, 0.133, 0.085], [1.343, 1.157, 1.181], [1.911, 1.961, 1.453], [19.241, 17.766, 14.414], [8.313, 6.497, 6.733], [7.899, 13.395, 6.868], [0.863, 0.754, 0.741], [0.409, 0.086, 0.083], [0.189, 0.043, 0.036], [0.045, 0.677, 0.037], [0.153, 0.416, 0.150], [0.025, 0.020, 0.020], [0.159, 0.022, 0.022], [0.014, 0.012, 0.014]
]
}
diff --git a/clickhouse-cloud/results/azure.3.32.json b/clickhouse-cloud/results/azure.3.32.json
index 29658cf6e..fae320e86 100644
--- a/clickhouse-cloud/results/azure.3.32.json
+++ b/clickhouse-cloud/results/azure.3.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 160.919,
- "data_size": 9946662199,
+ "load_time": 116.081,
+ "data_size": 9948397841,
"result": [
-[0.002, 0.002, 0.004], [0.524, 0.017, 0.599], [0.881, 0.074, 0.053], [0.150, 5.378, 0.495], [5.478, 1.053, 0.984], [1.324, 1.051, 5.595], [0.144, 0.111, 0.026], [0.052, 0.015, 0.024], [5.501, 5.532, 0.542], [0.745, 1.092, 0.668], [7.314, 2.114, 0.206], [0.362, 1.705, 0.271], [5.898, 1.207, 1.281], [6.457, 1.081, 1.109], [1.126, 1.609, 0.891], [1.377, 0.755, 0.754], [5.366, 2.820, 4.554], [2.588, 1.812, 2.492], [9.731, 10.782, 5.256], [0.047, 0.089, 0.006], [10.912, 14.756, 0.544], [1.423, 1.775, 0.165], [13.382, 0.767, 2.248], [29.936, 0.780, 0.755], [0.464, 1.126, 0.350], [0.329, 0.300, 0.251], [0.358, 0.465, 0.336], [1.554, 1.129, 1.171], [15.470, 14.932, 24.073], [0.423, 0.061, 0.062], [6.669, 7.251, 0.691], [9.754, 1.433, 1.070], [12.650, 3.684, 10.704], [5.694, 13.537, 3.346], [15.320, 3.352, 3.306], [0.882, 0.556, 0.888], [0.085, 0.090, 0.062], [0.046, 0.128, 0.031], [0.040, 0.036, 0.032], [0.177, 0.087, 0.173], [0.180, 0.024, 0.027], [0.025, 0.264, 0.024], [0.015, 0.014, 0.014]
+[0.002, 0.002, 0.002], [0.362, 0.020, 0.026], [0.685, 0.574, 0.085], [0.167, 0.084, 0.594], [0.869, 0.692, 0.673], [1.260, 1.516, 0.918], [0.037, 0.097, 0.021], [0.015, 0.035, 0.039], [0.623, 1.094, 0.776], [0.654, 0.636, 1.060], [1.249, 1.064, 0.247], [0.240, 0.238, 0.332], [1.047, 0.822, 0.703], [2.233, 1.619, 1.575], [1.170, 0.917, 0.771], [0.603, 0.928, 0.556], [1.915, 4.557, 2.318], [2.065, 1.096, 1.531], [4.317, 3.528, 6.092], [0.052, 0.005, 0.450], [6.525, 0.700, 0.670], [5.004, 1.818, 0.137], [3.493, 5.080, 1.044], [13.596, 1.424, 1.064], [0.356, 0.372, 0.348], [0.316, 0.310, 0.300], [0.421, 0.391, 0.340], [1.605, 1.379, 1.378], [11.826, 9.360, 6.971], [0.148, 0.068, 0.072], [0.720, 1.126, 0.679], [0.973, 0.978, 0.958], [5.591, 6.994, 3.500], [3.821, 3.239, 3.647], [3.736, 4.998, 3.532], [0.433, 0.623, 0.511], [0.080, 0.077, 0.061], [0.044, 0.047, 0.036], [0.035, 0.032, 0.030], [0.138, 0.148, 0.110], [0.015, 0.016, 0.025], [0.023, 0.016, 0.017], [0.014, 0.012, 0.012]
]
}
diff --git a/clickhouse-cloud/results/azure.3.64.json b/clickhouse-cloud/results/azure.3.64.json
index d0da71a13..3366310e8 100644
--- a/clickhouse-cloud/results/azure.3.64.json
+++ b/clickhouse-cloud/results/azure.3.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-16",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 100.421,
- "data_size": 9948742131,
+ "load_time": 105.649,
+ "data_size": 9949909978,
"result": [
-[0.002, 0.002, 0.002], [5.132, 0.047, 0.179], [0.217, 0.041, 0.035], [0.568, 0.543, 0.057], [0.394, 0.278, 0.270], [5.497, 1.120, 0.670], [0.012, 0.012, 0.012], [0.057, 0.049, 0.015], [5.613, 0.393, 0.724], [0.702, 0.747, 0.400], [0.135, 0.244, 0.148], [0.161, 0.177, 0.229], [0.844, 0.621, 0.459], [0.709, 0.627, 0.613], [0.663, 0.562, 0.555], [0.582, 0.512, 0.686], [1.199, 2.476, 1.648], [0.861, 0.876, 1.315], [5.752, 4.075, 6.514], [0.081, 0.020, 0.007], [12.171, 4.841, 0.312], [0.724, 0.091, 0.684], [7.929, 3.018, 0.710], [17.360, 0.738, 0.761], [0.192, 0.182, 0.181], [0.136, 0.158, 0.203], [0.260, 0.242, 0.204], [0.576, 0.959, 0.672], [9.592, 6.714, 8.576], [0.056, 0.243, 0.043], [0.650, 0.410, 0.399], [1.511, 0.551, 7.594], [1.925, 2.627, 4.235], [2.989, 3.120, 1.783], [1.714, 1.751, 1.732], [0.451, 0.316, 0.439], [0.051, 0.045, 0.048], [0.070, 0.043, 0.032], [0.045, 0.029, 0.049], [0.089, 0.088, 0.093], [0.021, 0.017, 0.019], [0.026, 0.024, 0.017], [0.015, 0.013, 0.019]
+[0.002, 0.002, 0.008], [0.606, 0.018, 0.024], [0.239, 0.036, 0.041], [0.569, 0.892, 0.167], [0.296, 0.590, 0.352], [0.943, 0.419, 1.325], [0.018, 0.020, 0.017], [0.084, 0.426, 0.013], [0.570, 0.708, 0.667], [0.769, 0.625, 0.476], [0.250, 0.189, 0.272], [0.251, 0.303, 0.278], [0.618, 0.417, 0.538], [0.604, 1.275, 0.696], [2.948, 0.448, 0.934], [0.628, 0.430, 0.333], [1.208, 2.391, 2.093], [1.594, 1.197, 1.229], [2.652, 4.536, 3.945], [0.029, 0.312, 0.321], [4.031, 0.871, 3.961], [0.871, 0.099, 0.838], [2.729, 1.492, 0.453], [13.997, 0.865, 0.780], [0.290, 0.224, 0.286], [0.168, 0.155, 0.206], [0.219, 0.682, 0.229], [0.698, 0.664, 0.731], [5.697, 5.985, 4.036], [0.058, 0.209, 0.179], [0.552, 0.760, 0.412], [1.177, 2.220, 1.099], [4.937, 3.265, 4.514], [3.395, 1.876, 3.334], [1.965, 3.160, 2.036], [0.243, 0.337, 0.243], [0.052, 0.041, 0.099], [0.027, 0.035, 0.033], [0.029, 0.049, 0.045], [0.145, 0.087, 0.104], [0.018, 0.030, 0.020], [0.026, 0.025, 0.017], [0.011, 0.013, 0.017]
]
}
diff --git a/clickhouse-cloud/results/azure.3.8.json b/clickhouse-cloud/results/azure.3.8.json
index 74c6258e4..7a6e602d4 100644
--- a/clickhouse-cloud/results/azure.3.8.json
+++ b/clickhouse-cloud/results/azure.3.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (azure)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "azure"],
- "load_time": 592.886,
- "data_size": 9946459119,
+ "load_time": 712.723,
+ "data_size": 9942834564,
"result": [
-[0.003, 0.011, 0.003], [0.328, 0.031, 0.033], [0.231, 0.334, 0.786], [1.085, 0.829, 0.769], [4.126, 5.587, 5.205], [6.177, 3.294, 3.849], [0.049, 0.055, 0.052], [0.037, 0.042, 0.036], [3.393, 5.671, 2.928], [3.809, 4.241, 5.425], [1.671, 1.908, 0.576], [1.752, 0.753, 0.757], [5.087, 10.029, 9.079], [11.229, 9.723, 8.680], [3.983, 3.348, 3.399], [3.902, 4.263, 3.843], [23.097, 21.958, 13.480], [10.853, 12.735, 15.558], [42.892, 88.999, 43.798], [0.120, 0.097, 0.140], [5.157, 1.954, 2.008], [6.895, 5.583, 5.109], [8.226, 6.173, 3.729], [7.465, 2.705, 3.464], [1.395, 1.288, 1.283], [0.941, 1.075, 0.877], [1.777, 1.714, 1.301], [5.807, 4.472, 6.048], [53.778, 54.059, 50.211], [0.186, 0.168, 0.159], [4.264, 2.398, 2.288], [3.495, 3.537, 6.356], [24.000, 20.761, 22.749], [24.055, 20.674, 35.439], [21.753, 22.826, 23.397], [1.453, 2.858, 1.361], [0.140, 0.259, 0.152], [0.064, 0.062, 0.102], [0.079, 0.057, 0.056], [0.291, 0.264, 0.462], [0.034, 0.033, 0.045], [0.029, 0.020, 0.034], [0.021, 0.023, 0.030]
+[0.002, 0.004, 0.003], [0.032, 0.259, 0.285], [0.193, 0.147, 0.402], [0.278, 0.243, 0.264], [1.744, 4.615, 2.237], [2.950, 2.990, 3.128], [0.038, 0.029, 0.050], [0.037, 0.041, 0.029], [2.865, 2.951, 2.654], [7.404, 6.478, 2.317], [0.506, 0.559, 0.509], [0.649, 0.671, 0.710], [2.256, 2.110, 2.598], [3.576, 6.041, 3.469], [3.128, 2.909, 2.778], [1.678, 1.295, 1.226], [8.913, 11.728, 10.460], [7.203, 14.871, 7.720], [17.590, 55.521, 16.888], [0.087, 0.200, 0.009], [10.463, 4.651, 1.900], [5.292, 11.128, 5.095], [6.003, 2.706, 5.781], [6.157, 6.216, 2.582], [1.323, 1.304, 1.228], [0.860, 0.841, 0.875], [1.214, 3.173, 3.088], [10.206, 7.517, 29.739], [37.122, 40.468, 29.966], [0.152, 0.209, 0.184], [4.165, 3.954, 2.495], [3.918, 6.661, 3.175], [21.613, 45.501, 26.652], [19.280, 33.392, 21.190], [18.492, 22.262, 20.974], [1.801, 1.836, 1.073], [0.138, 0.137, 0.215], [0.064, 0.057, 0.092], [0.071, 0.052, 0.047], [0.467, 0.438, 0.279], [0.053, 0.040, 0.029], [0.030, 0.022, 0.022], [0.020, 0.017, 0.018]
]
}
diff --git a/clickhouse-cloud/results/gcp.1.12.json b/clickhouse-cloud/results/gcp.1.12.json
index 98e84a007..30f6539b7 100644
--- a/clickhouse-cloud/results/gcp.1.12.json
+++ b/clickhouse-cloud/results/gcp.1.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 396.562,
- "data_size": 9940748285,
+ "load_time": 509.798,
+ "data_size": 9941171565,
"result": [
-[0.002, 0.003, 0.021], [0.101, 0.049, 0.023], [0.369, 0.354, 0.394], [0.505, 0.427, 0.405], [2.725, 2.262, 1.813], [2.725, 2.688, 2.816], [0.035, 0.033, 0.036], [0.024, 0.023, 0.030], [2.295, 2.812, 2.255], [2.670, 2.704, 2.366], [0.658, 0.689, 0.620], [0.812, 0.789, 0.818], [2.660, 2.924, 3.042], [4.301, 4.309, 4.235], [4.234, 4.338, 4.258], [2.361, 2.519, 2.321], [15.150, 11.558, 14.185], [7.838, 12.266, 11.127], [29.583, 29.398, 29.167], [0.062, 0.008, 0.008], [4.366, 1.883, 1.843], [5.149, 0.399, 0.425], [5.785, 2.657, 2.807], [2.546, 2.525, 2.438], [1.310, 1.382, 1.412], [0.877, 0.877, 0.878], [1.339, 1.370, 1.392], [4.266, 4.644, 4.551], [52.529, 52.792, 44.357], [0.131, 0.123, 0.109], [2.094, 1.893, 1.939], [2.695, 2.640, 2.477], [16.212, 18.918, 17.226], [15.312, 15.849, 15.215], [14.822, 15.065, 15.569], [1.318, 1.270, 1.168], [0.125, 0.115, 0.117], [0.049, 0.056, 0.044], [0.046, 0.043, 0.046], [0.232, 0.219, 0.231], [0.031, 0.027, 0.033], [0.020, 0.023, 0.019], [0.022, 0.017, 0.017]
+[0.004, 0.004, 0.023], [0.058, 0.044, 0.027], [0.315, 0.322, 0.393], [0.610, 0.518, 0.506], [2.547, 2.582, 2.447], [4.321, 5.548, 4.414], [0.047, 0.035, 0.039], [0.032, 0.030, 0.029], [4.049, 3.652, 2.670], [3.198, 3.237, 3.243], [0.646, 0.628, 0.619], [0.887, 0.828, 0.881], [3.778, 3.830, 3.382], [6.532, 7.949, 6.991], [5.858, 4.704, 4.336], [2.530, 2.331, 2.416], [17.540, 12.021, 16.614], [6.996, 12.831, 11.612], [31.237, 28.889, 33.438], [0.080, 0.011, 0.010], [5.219, 2.178, 2.114], [5.604, 0.495, 0.462], [6.884, 3.039, 3.088], [3.780, 3.028, 2.926], [1.613, 1.611, 1.628], [1.012, 0.953, 1.023], [1.572, 1.614, 1.603], [5.418, 4.930, 5.150], [33.970, 34.075, 36.099], [0.193, 0.133, 0.156], [3.398, 3.200, 3.249], [4.962, 5.010, 5.038], [30.515, 27.905, 30.160], [20.294, 20.301, 23.315], [21.179, 20.767, 20.025], [1.125, 1.331, 0.933], [0.166, 0.147, 0.129], [0.075, 0.067, 0.065], [0.059, 0.056, 0.047], [0.284, 0.307, 0.297], [0.051, 0.035, 0.031], [0.037, 0.043, 0.026], [0.033, 0.025, 0.019]
]
}
diff --git a/clickhouse-cloud/results/gcp.1.8.json b/clickhouse-cloud/results/gcp.1.8.json
index 37a900d65..989d4b056 100644
--- a/clickhouse-cloud/results/gcp.1.8.json
+++ b/clickhouse-cloud/results/gcp.1.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 1,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 671.129,
- "data_size": 9947861043,
+ "load_time": 697.382,
+ "data_size": 9949785336,
"result": [
-[0.002, 0.009, 0.009], [0.073, 0.059, 0.051], [0.556, 0.423, 0.440], [0.657, 0.661, 0.899], [4.911, 5.850, 6.150], [7.535, 9.210, 9.351], [0.121, 0.155, 0.159], [0.144, 0.089, 0.131], [8.214, 6.681, 5.879], [7.484, 7.445, 5.357], [1.320, 1.298, 1.308], [1.766, 1.785, 1.616], [7.316, 6.370, 7.067], [10.374, 14.043, 8.855], [9.011, 7.720, 7.538], [4.867, 4.565, 4.980], [30.991, 31.230, 33.885], [24.160, 18.906, 19.925], [39.600, 33.553, 33.112], [0.079, 0.011, 0.011], [6.634, 2.450, 2.345], [5.579, 0.532, 0.486], [6.659, 3.032, 3.210], [3.089, 2.793, 3.452], [1.533, 1.740, 1.457], [1.133, 1.089, 1.183], [1.650, 1.695, 1.635], [5.824, 5.881, 5.837], [71.635, 68.547, 65.999], [0.198, 0.199, 0.242], [3.291, 3.119, 3.165], [4.368, 4.357, 4.029], [33.367, 31.634, 28.802], [24.193, 23.568, 26.193], [29.636, 32.280, 29.519], [2.334, 2.124, 2.163], [0.257, 0.191, 0.270], [0.103, 0.076, 0.080], [0.071, 0.075, 0.080], [0.413, 0.431, 0.377], [0.051, 0.038, 0.040], [0.041, 0.035, 0.034], [0.030, 0.023, 0.048]
+[0.003, 0.019, 0.018], [0.134, 0.026, 0.098], [0.506, 0.502, 0.520], [0.838, 0.802, 0.937], [4.398, 4.113, 4.275], [5.016, 4.922, 4.942], [0.040, 0.038, 0.039], [0.032, 0.028, 0.073], [4.612, 4.248, 3.941], [4.824, 4.837, 4.380], [0.973, 0.889, 0.934], [1.227, 1.129, 1.103], [4.673, 4.291, 5.661], [10.871, 5.214, 8.053], [3.814, 4.282, 3.373], [2.335, 2.043, 1.897], [12.933, 12.939, 13.464], [10.361, 8.610, 9.313], [22.287, 22.628, 23.532], [0.087, 0.012, 0.009], [5.231, 2.057, 2.113], [5.163, 0.751, 0.508], [6.448, 2.907, 3.035], [2.946, 2.615, 2.614], [1.403, 1.424, 1.360], [0.903, 1.007, 0.963], [1.354, 1.389, 1.484], [4.758, 4.660, 4.788], [32.197, 31.957, 33.067], [0.158, 0.158, 0.169], [3.103, 2.849, 2.677], [4.207, 3.927, 3.813], [25.009, 25.945, 26.424], [24.745, 25.828, 27.133], [25.021, 24.085, 26.753], [1.344, 1.322, 1.311], [0.228, 0.169, 0.198], [0.073, 0.072, 0.058], [0.080, 0.062, 0.059], [0.315, 0.406, 0.452], [0.045, 0.037, 0.036], [0.028, 0.024, 0.026], [0.027, 0.021, 0.020]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.12.json b/clickhouse-cloud/results/gcp.2.12.json
index da51a995e..7236ee4b4 100644
--- a/clickhouse-cloud/results/gcp.2.12.json
+++ b/clickhouse-cloud/results/gcp.2.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 438.637,
- "data_size": 9942940238,
+ "load_time": 433.224,
+ "data_size": 9940430711,
"result": [
-[0.002, 0.003, 0.005], [0.059, 0.039, 0.319], [0.255, 0.307, 0.111], [0.634, 0.160, 0.167], [1.114, 2.415, 2.333], [2.296, 4.390, 1.800], [0.085, 0.209, 0.028], [0.101, 0.032, 0.134], [2.341, 2.239, 2.280], [3.234, 2.513, 1.688], [0.933, 0.567, 0.690], [0.871, 0.956, 0.996], [1.997, 1.795, 3.509], [2.932, 5.720, 5.192], [5.034, 2.822, 2.819], [1.542, 2.712, 1.425], [6.538, 13.546, 16.928], [4.335, 8.452, 13.677], [20.093, 18.032, 31.385], [0.338, 0.008, 0.088], [15.971, 4.843, 1.304], [3.431, 5.811, 0.554], [6.904, 3.275, 3.392], [3.639, 39.224, 1.723], [1.538, 0.908, 0.976], [1.384, 0.616, 0.992], [1.684, 0.893, 1.792], [3.952, 16.257, 4.322], [46.604, 45.582, 45.045], [0.149, 0.147, 0.131], [2.350, 3.727, 1.741], [7.052, 3.516, 2.223], [31.422, 25.078, 16.212], [20.641, 20.753, 15.126], [14.801, 14.174, 14.506], [1.229, 1.190, 1.446], [0.145, 0.314, 0.113], [0.315, 0.077, 0.057], [0.165, 0.040, 0.040], [0.261, 0.283, 0.207], [0.034, 0.316, 0.028], [0.031, 0.348, 0.021], [0.036, 0.027, 0.026]
+[0.003, 0.006, 0.003], [0.108, 0.031, 0.353], [0.433, 0.457, 0.162], [0.809, 0.238, 0.260], [1.262, 2.347, 2.212], [3.409, 2.681, 3.557], [0.204, 0.104, 0.049], [0.224, 0.045, 0.025], [2.354, 2.341, 2.104], [2.676, 2.624, 2.603], [0.744, 0.641, 0.522], [0.876, 0.742, 0.758], [3.245, 3.047, 3.236], [4.197, 3.905, 4.321], [2.972, 4.748, 3.633], [1.634, 2.105, 1.526], [7.396, 10.175, 9.794], [4.788, 9.108, 5.446], [23.972, 23.539, 22.343], [0.255, 0.058, 0.009], [4.564, 17.874, 1.882], [5.122, 0.457, 4.660], [18.595, 2.691, 2.775], [2.619, 2.467, 2.326], [1.207, 1.250, 1.323], [0.863, 0.838, 0.893], [1.320, 1.240, 1.401], [4.299, 4.720, 4.365], [41.258, 23.326, 21.299], [0.119, 0.104, 0.118], [4.873, 2.383, 1.938], [8.854, 3.518, 3.065], [22.567, 21.141, 25.727], [32.776, 16.735, 20.731], [21.694, 15.951, 15.468], [1.072, 0.939, 0.945], [0.121, 0.138, 0.386], [0.329, 0.051, 0.047], [0.206, 0.048, 0.049], [0.575, 0.255, 0.278], [0.432, 0.035, 0.034], [0.028, 0.023, 0.029], [0.258, 0.026, 0.021]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.120.json b/clickhouse-cloud/results/gcp.2.120.json
index 0e6df67c4..e10735a80 100644
--- a/clickhouse-cloud/results/gcp.2.120.json
+++ b/clickhouse-cloud/results/gcp.2.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 75.616,
- "data_size": 9951005106,
+ "load_time": 80.315,
+ "data_size": 9950558500,
"result": [
-[0.002, 0.003, 0.002], [0.531, 0.027, 0.019], [0.043, 0.033, 0.037], [0.046, 0.039, 0.393], [0.298, 0.351, 0.241], [0.312, 0.310, 0.593], [0.192, 0.016, 0.019], [0.018, 0.165, 0.019], [0.591, 0.355, 0.312], [0.380, 0.738, 0.452], [0.156, 0.320, 0.193], [0.427, 0.168, 0.194], [0.661, 0.477, 0.455], [0.662, 0.678, 0.621], [0.448, 0.414, 0.397], [0.284, 0.248, 0.249], [1.710, 1.289, 1.261], [0.772, 0.735, 0.720], [2.966, 2.081, 2.557], [0.021, 0.125, 0.007], [2.029, 0.340, 0.440], [0.633, 0.128, 0.112], [0.629, 0.340, 2.046], [0.445, 44.064, 0.587], [0.171, 0.168, 0.204], [0.132, 0.106, 0.115], [0.183, 0.158, 0.190], [0.452, 0.472, 0.475], [4.483, 5.962, 5.024], [0.041, 0.178, 0.041], [0.314, 0.279, 0.690], [0.452, 1.183, 0.518], [2.593, 2.188, 2.111], [1.800, 1.540, 1.713], [1.784, 1.623, 1.974], [0.268, 0.365, 0.246], [0.063, 0.051, 0.200], [0.037, 0.045, 0.036], [0.212, 0.037, 0.038], [0.248, 0.102, 0.105], [0.021, 0.277, 0.021], [0.199, 0.023, 0.022], [0.016, 0.019, 0.017]
+[0.003, 0.005, 0.002], [0.430, 0.025, 0.022], [0.304, 0.035, 0.034], [0.052, 0.049, 0.402], [0.346, 0.299, 0.308], [0.638, 0.330, 0.332], [0.014, 0.190, 0.014], [0.020, 0.176, 0.018], [0.363, 0.591, 0.358], [0.378, 0.395, 0.552], [0.164, 0.309, 0.197], [0.324, 0.178, 0.167], [0.436, 0.385, 0.406], [0.560, 0.721, 0.597], [0.655, 0.367, 0.396], [0.332, 0.309, 0.231], [1.137, 0.934, 1.156], [0.697, 0.814, 0.912], [2.697, 2.508, 2.571], [0.107, 0.007, 0.027], [2.155, 0.513, 1.315], [0.558, 0.611, 0.091], [2.118, 0.697, 0.403], [0.500, 0.496, 0.533], [0.171, 0.166, 0.174], [0.131, 0.112, 0.143], [0.185, 0.183, 0.182], [0.515, 0.587, 0.415], [3.177, 3.928, 3.227], [0.047, 0.265, 0.040], [0.816, 0.314, 0.310], [1.182, 0.394, 0.615], [3.107, 2.777, 2.135], [1.547, 1.376, 1.734], [1.439, 1.403, 1.699], [0.187, 0.206, 0.159], [0.272, 0.062, 0.055], [0.035, 0.034, 0.039], [0.040, 0.188, 0.036], [0.299, 0.099, 0.099], [0.264, 0.024, 0.023], [0.198, 0.019, 0.025], [0.014, 0.298, 0.015]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.16.json b/clickhouse-cloud/results/gcp.2.16.json
index f65887ba0..919e5beba 100644
--- a/clickhouse-cloud/results/gcp.2.16.json
+++ b/clickhouse-cloud/results/gcp.2.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 287.557,
- "data_size": 9943221654,
+ "load_time": 292.146,
+ "data_size": 9942327697,
"result": [
-[0.002, 0.002, 0.002], [0.051, 0.403, 0.023], [0.179, 0.301, 0.176], [0.310, 0.261, 0.607], [1.426, 1.371, 1.539], [1.829, 1.391, 1.260], [0.213, 0.037, 0.052], [0.097, 0.026, 0.023], [1.661, 1.499, 1.434], [1.476, 1.283, 1.393], [0.482, 0.412, 0.337], [0.586, 0.431, 0.454], [1.949, 1.492, 1.772], [3.107, 2.367, 2.131], [2.582, 2.506, 2.509], [1.546, 1.266, 2.040], [5.092, 7.457, 4.328], [4.273, 4.710, 3.309], [19.331, 11.287, 19.027], [0.274, 0.052, 0.008], [2.940, 11.853, 1.408], [3.469, 0.330, 2.581], [12.537, 1.514, 4.092], [1.897, 38.773, 1.328], [1.001, 0.730, 0.921], [0.621, 0.625, 0.636], [0.720, 0.724, 1.043], [2.305, 2.244, 2.275], [35.969, 27.015, 27.561], [0.309, 0.106, 0.089], [2.806, 1.437, 1.394], [2.404, 2.339, 5.276], [14.377, 12.268, 12.182], [16.050, 11.316, 6.737], [7.140, 6.759, 6.940], [1.012, 0.983, 0.928], [0.108, 0.311, 0.095], [0.048, 0.276, 0.053], [0.192, 0.046, 0.058], [0.546, 0.183, 0.163], [0.027, 0.247, 0.022], [0.285, 0.022, 0.023], [0.243, 0.019, 0.015]
+[0.002, 0.003, 0.003], [0.284, 0.052, 0.028], [0.482, 0.118, 0.198], [0.280, 0.252, 0.273], [1.656, 1.394, 1.158], [1.761, 2.510, 1.865], [0.025, 0.025, 0.183], [0.021, 0.150, 0.027], [1.504, 2.000, 1.892], [2.626, 1.992, 2.472], [0.446, 0.781, 0.494], [0.524, 0.484, 0.705], [2.325, 2.277, 1.967], [3.671, 3.646, 3.031], [2.174, 1.937, 1.969], [1.297, 1.426, 1.280], [5.724, 5.296, 4.926], [2.917, 3.566, 3.891], [11.074, 14.418, 9.220], [0.050, 0.296, 0.011], [13.490, 3.291, 1.399], [3.339, 3.359, 0.361], [13.965, 3.825, 1.749], [53.637, 1.989, 1.908], [1.000, 0.988, 0.860], [0.649, 0.626, 0.736], [0.868, 1.063, 0.888], [3.131, 2.887, 2.872], [19.396, 18.783, 28.984], [0.336, 0.125, 0.085], [1.367, 4.081, 1.283], [6.827, 3.246, 2.232], [27.315, 31.708, 14.543], [7.347, 25.254, 6.946], [14.626, 6.987, 11.531], [0.768, 0.683, 1.114], [0.339, 0.133, 0.148], [0.430, 0.050, 0.061], [0.053, 0.237, 0.062], [0.469, 0.260, 0.167], [0.023, 0.373, 0.033], [0.298, 0.033, 0.021], [0.225, 0.024, 0.018]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.236.json b/clickhouse-cloud/results/gcp.2.236.json
index b7841714f..8fe4a456e 100644
--- a/clickhouse-cloud/results/gcp.2.236.json
+++ b/clickhouse-cloud/results/gcp.2.236.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 236GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 90.293,
- "data_size": 9950621157,
+ "load_time": 68.810,
+ "data_size": 9952176336,
"result": [
-[0.003, 0.003, 0.004], [0.487, 0.027, 0.026], [0.046, 0.036, 0.462], [0.046, 0.289, 0.153], [0.243, 0.317, 0.210], [0.256, 0.250, 0.551], [0.186, 0.019, 0.021], [0.027, 0.027, 0.027], [0.715, 0.457, 0.449], [0.426, 0.493, 0.469], [0.163, 0.162, 0.354], [0.348, 0.154, 0.169], [0.325, 0.284, 0.255], [0.554, 0.439, 0.419], [0.325, 0.302, 0.478], [0.243, 0.227, 0.191], [0.686, 0.688, 0.666], [0.541, 0.499, 0.612], [1.817, 1.515, 1.421], [0.027, 0.007, 0.105], [0.274, 0.206, 1.362], [0.998, 0.345, 0.088], [0.366, 0.243, 1.164], [46.769, 0.389, 0.354], [0.122, 0.122, 0.131], [0.088, 0.092, 0.096], [0.123, 0.164, 0.130], [0.382, 0.381, 0.521], [2.423, 2.337, 2.294], [0.168, 0.045, 0.046], [0.281, 0.272, 0.277], [0.413, 0.345, 0.337], [2.316, 1.417, 1.713], [1.143, 1.052, 1.386], [1.121, 1.309, 1.144], [0.143, 0.159, 0.148], [0.085, 0.259, 0.045], [0.042, 0.038, 0.049], [0.047, 0.043, 0.185], [0.120, 0.351, 0.098], [0.318, 0.026, 0.033], [0.182, 0.022, 0.023], [0.029, 0.016, 0.018]
+[0.002, 0.002, 0.002], [0.394, 0.023, 0.084], [0.269, 0.031, 0.029], [0.306, 0.036, 0.048], [0.230, 0.217, 0.203], [0.455, 0.227, 0.241], [0.015, 0.015, 0.178], [0.019, 0.017, 0.017], [0.415, 0.598, 0.415], [0.436, 0.446, 0.411], [0.137, 0.134, 0.400], [0.142, 0.361, 0.147], [0.288, 0.204, 0.262], [0.334, 0.323, 0.340], [0.552, 0.294, 0.285], [0.232, 0.131, 0.171], [0.656, 0.545, 0.701], [0.394, 0.393, 0.394], [1.515, 1.396, 1.109], [0.207, 0.005, 0.005], [0.289, 1.350, 0.162], [0.335, 0.070, 0.064], [0.448, 0.281, 1.185], [56.369, 10.695, 0.336], [0.127, 0.452, 0.122], [0.101, 0.092, 0.089], [0.120, 0.131, 0.117], [0.417, 0.356, 0.354], [1.751, 1.745, 2.314], [0.169, 0.038, 0.036], [0.423, 0.276, 0.251], [0.415, 0.340, 0.343], [1.481, 1.373, 2.026], [1.054, 1.021, 1.044], [1.268, 1.096, 1.064], [0.100, 0.105, 0.100], [0.043, 0.240, 0.054], [0.031, 0.032, 0.031], [0.178, 0.031, 0.028], [0.189, 0.077, 0.096], [0.017, 0.228, 0.018], [0.178, 0.018, 0.017], [0.014, 0.013, 0.014]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.32.json b/clickhouse-cloud/results/gcp.2.32.json
index 23e47c5fd..7d6e28658 100644
--- a/clickhouse-cloud/results/gcp.2.32.json
+++ b/clickhouse-cloud/results/gcp.2.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 147.070,
- "data_size": 9945925540,
+ "load_time": 170.094,
+ "data_size": 9948261201,
"result": [
-[0.111, 0.004, 0.003], [0.096, 1.115, 0.134], [0.166, 0.146, 0.909], [1.185, 0.162, 0.142], [0.734, 0.800, 0.688], [1.076, 1.118, 1.288], [0.194, 0.030, 0.026], [0.019, 0.019, 0.021], [0.989, 1.150, 0.832], [0.963, 0.999, 1.101], [0.426, 0.241, 0.265], [0.493, 0.354, 0.338], [1.017, 0.950, 0.979], [1.564, 1.542, 1.513], [1.699, 1.144, 1.612], [0.929, 0.899, 0.803], [3.336, 2.820, 3.348], [1.789, 1.871, 1.806], [7.764, 5.874, 6.013], [0.175, 0.008, 0.033], [1.325, 6.019, 0.533], [1.412, 0.573, 0.159], [6.437, 1.703, 0.872], [43.253, 0.808, 0.869], [0.383, 0.386, 0.422], [0.275, 0.286, 0.292], [0.397, 0.377, 0.383], [1.257, 1.351, 1.287], [19.010, 15.247, 15.798], [0.069, 0.062, 0.183], [1.240, 0.882, 0.818], [2.982, 1.323, 1.534], [4.102, 4.013, 4.337], [4.374, 4.256, 4.065], [4.060, 4.318, 4.388], [0.535, 0.685, 0.597], [0.059, 0.199, 0.083], [0.038, 0.051, 0.048], [0.168, 0.050, 0.036], [0.116, 0.106, 0.271], [0.023, 0.293, 0.021], [0.166, 0.022, 0.021], [0.016, 0.016, 0.019]
+[0.010, 0.002, 0.002], [0.064, 0.030, 0.394], [0.199, 0.187, 0.441], [0.484, 0.199, 0.109], [0.570, 1.436, 0.540], [1.564, 1.080, 1.490], [0.025, 0.021, 0.019], [0.142, 0.019, 0.127], [1.128, 0.811, 1.050], [1.246, 0.858, 0.684], [0.333, 0.317, 0.291], [0.341, 0.334, 0.404], [1.329, 1.184, 0.924], [1.881, 1.971, 1.396], [1.192, 1.512, 0.876], [0.716, 0.484, 0.446], [4.077, 3.262, 2.440], [1.676, 1.534, 1.500], [5.082, 4.477, 5.394], [0.160, 0.006, 0.037], [6.828, 1.435, 0.575], [1.572, 1.584, 0.173], [7.054, 2.699, 0.981], [1.111, 1.020, 40.482], [0.363, 0.421, 0.365], [0.253, 0.289, 0.342], [0.464, 0.442, 0.359], [1.236, 1.202, 1.394], [13.544, 8.033, 9.283], [0.066, 0.066, 0.064], [1.300, 0.924, 0.742], [3.012, 0.870, 0.848], [6.353, 6.322, 4.620], [3.659, 3.627, 4.747], [3.729, 3.762, 3.620], [0.383, 0.580, 0.445], [0.072, 0.074, 0.073], [0.176, 0.036, 0.038], [0.036, 0.241, 0.041], [0.135, 0.228, 0.121], [0.265, 0.023, 0.026], [0.021, 0.021, 0.167], [0.015, 0.017, 0.015]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.64.json b/clickhouse-cloud/results/gcp.2.64.json
index 7464aae1c..3fcb8019e 100644
--- a/clickhouse-cloud/results/gcp.2.64.json
+++ b/clickhouse-cloud/results/gcp.2.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 85.551,
- "data_size": 9946772558,
+ "load_time": 78.485,
+ "data_size": 9947829051,
"result": [
-[0.003, 0.002, 0.002], [0.562, 0.024, 0.023], [0.052, 0.389, 0.198], [0.346, 0.061, 0.058], [0.431, 0.370, 0.342], [0.736, 0.521, 0.508], [0.015, 0.017, 0.153], [0.019, 0.022, 0.020], [0.483, 0.584, 0.503], [0.513, 0.477, 0.626], [0.321, 0.161, 0.174], [0.191, 0.199, 0.349], [0.584, 0.583, 0.615], [0.871, 0.691, 0.918], [0.802, 1.017, 0.615], [0.377, 0.367, 0.461], [1.725, 1.620, 1.581], [1.073, 1.276, 1.210], [3.562, 2.763, 3.160], [0.104, 0.009, 0.007], [3.459, 0.377, 0.622], [0.737, 0.856, 0.099], [0.859, 0.438, 3.348], [0.560, 0.531, 0.533], [0.239, 0.270, 0.238], [0.203, 0.153, 0.151], [0.275, 0.256, 0.218], [0.798, 0.642, 0.614], [7.257, 10.627, 8.202], [0.049, 0.043, 0.044], [0.839, 0.511, 0.492], [0.679, 0.650, 1.909], [2.341, 2.289, 2.577], [2.289, 2.249, 2.351], [2.528, 2.280, 2.349], [0.308, 0.368, 0.394], [0.081, 0.199, 0.070], [0.042, 0.044, 0.048], [0.044, 0.187, 0.042], [0.117, 0.282, 0.115], [0.324, 0.030, 0.023], [0.024, 0.025, 0.275], [0.020, 0.016, 0.020]
+[0.003, 0.003, 0.002], [0.022, 0.024, 0.255], [0.049, 0.044, 0.244], [0.055, 0.287, 0.115], [0.319, 0.457, 0.385], [0.715, 0.529, 0.512], [0.160, 0.013, 0.013], [0.106, 0.016, 0.016], [0.445, 0.465, 0.469], [0.566, 0.880, 0.475], [0.167, 0.169, 0.308], [0.176, 0.205, 0.316], [0.601, 0.556, 0.493], [0.773, 0.723, 0.702], [0.816, 0.524, 0.559], [0.290, 0.265, 0.252], [1.179, 1.461, 1.216], [0.667, 0.861, 0.698], [3.262, 2.288, 2.272], [0.117, 0.007, 0.024], [0.864, 0.363, 0.340], [3.803, 0.740, 0.089], [0.842, 0.445, 3.566], [38.828, 0.536, 0.562], [0.222, 0.219, 0.232], [0.156, 0.150, 0.144], [0.210, 0.246, 0.231], [0.652, 0.658, 0.778], [7.049, 4.698, 4.690], [0.161, 0.051, 0.041], [0.722, 0.498, 0.513], [1.681, 0.624, 0.657], [2.742, 2.340, 2.336], [2.179, 2.552, 2.226], [2.321, 2.216, 2.157], [0.271, 0.275, 0.301], [0.055, 0.051, 0.171], [0.038, 0.034, 0.038], [0.142, 0.039, 0.033], [0.153, 0.081, 0.110], [0.401, 0.019, 0.020], [0.189, 0.019, 0.021], [0.016, 0.015, 0.014]
]
}
diff --git a/clickhouse-cloud/results/gcp.2.8.json b/clickhouse-cloud/results/gcp.2.8.json
index 1688ea5f7..b6c25f0a5 100644
--- a/clickhouse-cloud/results/gcp.2.8.json
+++ b/clickhouse-cloud/results/gcp.2.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 2,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 624.235,
- "data_size": 9946472478,
+ "load_time": 611.293,
+ "data_size": 9947077545,
"result": [
-[0.002, 0.003, 0.003], [0.436, 0.101, 0.027], [0.489, 0.485, 0.453], [0.932, 0.638, 0.509], [2.048, 1.976, 3.277], [5.523, 4.064, 4.729], [0.036, 0.297, 0.046], [0.031, 0.029, 0.124], [4.031, 3.983, 3.735], [5.097, 4.084, 5.364], [0.892, 1.071, 1.015], [1.369, 1.248, 1.048], [5.071, 3.789, 3.188], [8.329, 5.543, 5.561], [7.926, 7.850, 6.558], [3.138, 4.210, 3.896], [22.415, 19.156, 15.050], [12.186, 13.088, 12.221], [38.042, 31.820, 33.293], [0.083, 0.356, 0.010], [26.472, 4.850, 1.936], [5.362, 6.587, 0.535], [25.827, 6.443, 3.508], [44.375, 2.833, 2.906], [1.655, 1.515, 1.658], [1.069, 0.972, 1.079], [1.408, 1.446, 1.447], [4.730, 5.520, 5.878], [81.599, 66.310, 57.415], [0.159, 0.150, 0.325], [3.321, 4.205, 3.137], [4.248, 11.743, 4.316], [31.036, 33.499, 35.478], [24.170, 24.829, 28.875], [29.419, 23.913, 23.106], [1.865, 1.767, 1.752], [0.212, 0.201, 0.216], [0.079, 0.074, 0.080], [0.066, 0.137, 0.077], [0.371, 0.366, 0.356], [0.040, 0.251, 0.033], [0.027, 0.031, 0.031], [0.367, 0.026, 0.031]
+[0.007, 0.002, 0.002], [0.108, 0.070, 0.075], [1.333, 0.197, 0.539], [1.131, 0.280, 0.302], [5.268, 4.199, 1.922], [3.858, 5.896, 4.124], [0.060, 0.179, 0.044], [0.032, 0.028, 0.029], [3.539, 3.316, 3.404], [3.773, 4.090, 3.157], [1.021, 1.037, 1.023], [0.915, 0.839, 1.211], [2.888, 2.989, 3.358], [4.843, 4.527, 4.369], [4.216, 3.064, 3.109], [2.235, 2.001, 1.939], [10.746, 8.527, 10.835], [9.087, 9.130, 4.989], [20.541, 27.620, 18.368], [0.076, 0.008, 0.303], [4.921, 2.001, 25.413], [5.433, 0.504, 5.309], [6.056, 2.703, 25.185], [2.726, 50.638, 3.175], [1.460, 1.353, 1.316], [0.903, 0.946, 0.941], [1.443, 1.390, 1.370], [4.623, 4.540, 4.721], [49.682, 31.597, 30.270], [0.223, 0.163, 0.149], [3.649, 3.052, 2.882], [11.418, 4.180, 3.572], [25.120, 23.947, 29.878], [25.330, 21.802, 21.039], [25.127, 20.982, 21.888], [1.279, 1.354, 1.393], [0.169, 0.159, 0.207], [0.075, 0.076, 0.065], [0.060, 0.061, 0.125], [0.317, 0.374, 0.326], [0.033, 0.225, 0.040], [0.030, 0.254, 0.025], [0.022, 0.019, 0.019]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.12.json b/clickhouse-cloud/results/gcp.3.12.json
index defc75cb5..945d1f67d 100644
--- a/clickhouse-cloud/results/gcp.3.12.json
+++ b/clickhouse-cloud/results/gcp.3.12.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 12GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 405.591,
- "data_size": 9941059364,
+ "load_time": 424.457,
+ "data_size": 9946063765,
"result": [
-[0.002, 0.004, 0.002], [0.072, 0.044, 0.438], [0.570, 0.308, 0.329], [0.770, 0.800, 0.174], [1.191, 1.154, 1.158], [3.630, 2.398, 2.141], [0.224, 0.160, 0.032], [0.311, 0.028, 0.075], [3.149, 1.821, 2.775], [3.248, 3.173, 2.034], [0.631, 0.588, 0.666], [0.761, 0.855, 0.666], [2.281, 1.992, 2.990], [3.517, 4.857, 3.004], [3.430, 2.453, 3.027], [1.541, 1.601, 1.625], [7.305, 11.478, 7.198], [4.711, 4.874, 7.611], [25.300, 20.041, 19.360], [0.059, 0.008, 0.256], [15.582, 15.546, 1.313], [3.434, 5.248, 0.456], [6.172, 2.883, 16.479], [5.965, 39.976, 2.742], [1.416, 0.872, 1.616], [0.651, 1.046, 0.633], [1.003, 1.135, 0.932], [3.397, 17.229, 2.984], [46.843, 37.109, 37.409], [0.271, 0.199, 0.143], [2.796, 1.948, 3.590], [2.733, 6.833, 2.480], [25.881, 18.794, 19.631], [29.379, 16.171, 15.171], [16.513, 15.164, 15.415], [1.243, 1.353, 1.336], [0.320, 0.216, 0.133], [0.327, 0.198, 0.059], [0.054, 0.176, 0.116], [0.382, 0.218, 0.616], [0.028, 0.377, 0.027], [0.028, 0.026, 0.283], [0.241, 0.021, 0.226]
+[0.002, 0.002, 0.002], [0.508, 0.019, 0.023], [0.470, 0.203, 0.116], [0.688, 0.634, 0.195], [2.284, 1.195, 1.066], [2.298, 1.831, 3.828], [0.152, 0.031, 0.201], [0.036, 0.151, 0.058], [3.129, 1.750, 1.565], [2.495, 2.715, 2.095], [0.642, 0.575, 0.981], [0.691, 0.732, 0.569], [4.532, 4.941, 1.872], [5.775, 3.704, 2.869], [3.176, 2.219, 3.862], [1.445, 1.251, 1.220], [6.098, 6.060, 8.048], [5.978, 5.914, 5.897], [18.929, 14.565, 24.984], [0.234, 0.057, 0.162], [16.288, 4.723, 1.430], [5.148, 3.592, 0.324], [6.387, 31.534, 3.056], [3.108, 40.970, 4.197], [1.748, 2.172, 0.913], [0.642, 0.760, 0.775], [0.941, 0.888, 0.902], [16.959, 3.191, 3.050], [33.403, 20.516, 20.402], [0.268, 0.113, 0.255], [2.854, 1.871, 2.352], [3.157, 7.954, 6.359], [25.189, 17.464, 18.743], [15.272, 15.303, 15.388], [14.931, 15.475, 19.013], [1.019, 1.022, 0.861], [0.433, 0.252, 0.120], [0.489, 0.252, 0.063], [0.158, 0.048, 0.136], [0.393, 0.659, 0.220], [0.322, 0.056, 0.177], [0.033, 0.357, 0.026], [0.017, 0.017, 0.018]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.120.json b/clickhouse-cloud/results/gcp.3.120.json
index fbc75c4f8..924cb0115 100644
--- a/clickhouse-cloud/results/gcp.3.120.json
+++ b/clickhouse-cloud/results/gcp.3.120.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 120GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 74.495,
- "data_size": 9951313728,
+ "load_time": 76.462,
+ "data_size": 9950389373,
"result": [
-[0.002, 0.002, 0.003], [0.260, 0.212, 0.086], [0.338, 0.034, 0.034], [0.283, 0.250, 0.044], [0.293, 0.280, 0.288], [0.611, 0.487, 0.315], [0.016, 0.173, 0.014], [0.146, 0.017, 0.019], [0.361, 0.548, 0.345], [0.494, 0.337, 0.343], [0.372, 0.179, 0.276], [0.190, 0.384, 0.200], [0.409, 0.401, 0.298], [0.539, 0.528, 0.564], [0.672, 0.489, 0.603], [0.363, 0.344, 0.334], [1.301, 1.218, 1.057], [0.781, 0.762, 0.830], [2.401, 1.962, 1.989], [0.222, 0.007, 0.056], [2.114, 0.226, 0.450], [1.404, 0.083, 0.477], [1.864, 0.289, 0.582], [54.808, 0.418, 0.470], [0.187, 0.177, 0.166], [0.115, 0.122, 0.112], [0.151, 0.203, 0.182], [0.612, 0.438, 0.530], [5.579, 4.208, 4.637], [0.268, 0.038, 0.041], [0.370, 0.546, 0.320], [1.095, 0.762, 0.462], [1.974, 2.294, 2.405], [1.426, 1.499, 1.473], [1.377, 1.533, 1.609], [0.276, 0.267, 0.273], [0.194, 0.055, 0.050], [0.034, 0.033, 0.034], [0.194, 0.174, 0.039], [0.469, 0.089, 0.191], [0.024, 0.025, 0.025], [0.297, 0.246, 0.019], [0.015, 0.016, 0.015]
+[0.003, 0.002, 0.002], [0.327, 0.019, 0.176], [0.254, 0.076, 0.033], [0.377, 0.046, 0.055], [0.334, 0.393, 0.268], [0.590, 0.480, 0.528], [0.150, 0.013, 0.113], [0.133, 0.016, 0.017], [0.543, 0.372, 0.541], [0.487, 0.390, 0.580], [0.160, 0.312, 0.165], [0.165, 0.311, 0.297], [0.430, 0.404, 0.395], [0.541, 0.554, 0.562], [0.619, 0.389, 0.481], [0.295, 0.359, 0.272], [0.994, 0.915, 0.959], [0.567, 0.782, 0.692], [1.944, 2.253, 1.952], [0.110, 0.007, 0.007], [2.088, 0.208, 1.143], [0.496, 0.099, 0.554], [1.944, 1.266, 1.134], [51.831, 0.461, 50.797], [0.168, 0.165, 0.166], [0.126, 0.451, 0.115], [0.150, 0.151, 0.150], [0.581, 0.568, 0.529], [3.823, 2.899, 3.381], [0.095, 0.038, 0.037], [0.339, 0.319, 0.470], [1.168, 0.823, 0.528], [2.140, 2.303, 2.877], [1.483, 1.396, 1.553], [1.448, 1.473, 1.678], [0.226, 0.199, 0.165], [0.297, 0.261, 0.057], [0.042, 0.043, 0.038], [0.214, 0.129, 0.033], [0.225, 0.167, 0.090], [0.373, 0.022, 0.173], [0.174, 0.185, 0.021], [0.015, 0.014, 0.016]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.16.json b/clickhouse-cloud/results/gcp.3.16.json
index ff32168eb..7e4329e74 100644
--- a/clickhouse-cloud/results/gcp.3.16.json
+++ b/clickhouse-cloud/results/gcp.3.16.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 16GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 289.010,
- "data_size": 9940233961,
+ "load_time": 326.896,
+ "data_size": 9942171811,
"result": [
-[0.003, 0.002, 0.002], [0.418, 0.047, 0.020], [0.768, 0.094, 0.145], [0.176, 0.536, 0.135], [1.409, 0.895, 1.211], [1.706, 2.317, 1.387], [0.259, 0.026, 0.028], [0.145, 0.024, 0.097], [1.574, 1.998, 1.317], [1.803, 1.815, 1.830], [0.509, 0.420, 0.365], [0.553, 0.585, 0.552], [1.814, 1.465, 1.562], [2.518, 2.579, 2.342], [2.719, 2.288, 2.497], [1.682, 1.743, 1.348], [5.404, 5.392, 5.446], [4.976, 4.958, 4.485], [25.972, 11.300, 14.393], [0.189, 0.049, 0.010], [3.049, 12.080, 10.412], [3.804, 2.690, 2.598], [12.115, 11.605, 1.501], [38.233, 2.040, 1.748], [0.992, 0.712, 0.967], [0.511, 0.556, 0.484], [0.932, 0.732, 0.727], [2.444, 2.850, 2.374], [35.531, 35.676, 35.776], [0.260, 0.172, 0.088], [3.061, 1.413, 1.425], [6.371, 2.396, 4.461], [14.069, 14.367, 13.138], [17.469, 10.930, 6.905], [7.328, 19.402, 7.051], [1.045, 0.863, 0.971], [0.100, 0.110, 0.409], [0.290, 0.045, 0.047], [0.050, 0.200, 0.051], [0.175, 0.552, 0.171], [0.025, 0.026, 0.256], [0.237, 0.139, 0.026], [0.346, 0.105, 0.021]
+[0.002, 0.003, 0.003], [0.417, 0.113, 0.020], [0.148, 0.214, 0.162], [0.244, 0.661, 0.137], [1.918, 1.490, 0.972], [2.032, 2.382, 1.788], [0.159, 0.023, 0.021], [0.183, 0.195, 0.022], [1.694, 1.320, 1.382], [1.894, 1.750, 1.522], [0.520, 0.473, 0.446], [0.561, 0.463, 0.539], [1.678, 1.674, 1.498], [3.328, 2.198, 2.466], [1.855, 2.621, 1.847], [1.509, 1.467, 1.330], [4.798, 5.031, 6.421], [2.518, 3.334, 3.115], [16.047, 25.068, 12.607], [0.049, 0.238, 0.008], [13.364, 1.152, 3.033], [3.322, 2.760, 0.298], [13.520, 4.122, 1.532], [1.890, 40.693, 2.038], [0.852, 0.898, 0.874], [0.575, 0.528, 0.523], [0.767, 0.758, 0.768], [13.451, 3.164, 3.141], [26.267, 24.642, 15.439], [0.294, 0.194, 0.100], [1.368, 3.197, 1.700], [6.630, 4.562, 2.193], [16.966, 16.097, 15.023], [17.482, 7.571, 11.518], [18.332, 7.900, 7.533], [0.891, 0.878, 0.851], [0.307, 0.210, 0.115], [0.252, 0.425, 0.061], [0.152, 0.111, 0.054], [0.353, 0.492, 0.227], [0.314, 0.023, 0.033], [0.262, 0.026, 0.108], [0.217, 0.017, 0.018]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.236.json b/clickhouse-cloud/results/gcp.3.236.json
index f8cc7e33b..248e36356 100644
--- a/clickhouse-cloud/results/gcp.3.236.json
+++ b/clickhouse-cloud/results/gcp.3.236.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 236GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 89.672,
- "data_size": 9950396333,
+ "load_time": 72.185,
+ "data_size": 9951433337,
"result": [
-[0.003, 0.002, 0.003], [0.302, 0.032, 0.029], [0.347, 0.038, 0.028], [0.323, 0.050, 0.044], [0.324, 0.245, 0.372], [0.489, 0.244, 0.242], [0.165, 0.017, 0.025], [0.110, 0.029, 0.027], [0.449, 0.422, 0.415], [0.818, 0.502, 0.559], [0.435, 0.163, 0.150], [0.429, 0.152, 0.154], [0.389, 0.329, 0.333], [0.388, 0.682, 0.538], [0.514, 0.383, 0.637], [0.245, 0.194, 0.898], [0.643, 0.605, 0.603], [0.389, 0.371, 0.418], [1.273, 1.812, 1.164], [0.023, 0.205, 0.006], [1.282, 0.268, 0.885], [0.336, 0.073, 0.344], [1.133, 0.797, 0.374], [0.381, 46.595, 0.355], [0.141, 0.127, 0.140], [0.098, 0.099, 0.119], [0.129, 0.125, 0.111], [0.418, 0.350, 0.535], [3.007, 2.885, 2.360], [0.296, 0.049, 0.065], [0.306, 0.591, 0.269], [0.901, 0.401, 0.427], [1.135, 1.138, 1.329], [1.202, 1.120, 1.046], [1.312, 1.408, 1.113], [0.309, 0.146, 0.134], [0.306, 0.073, 0.051], [0.043, 0.045, 0.046], [0.201, 0.160, 0.041], [0.174, 0.252, 0.124], [0.296, 0.223, 0.035], [0.180, 0.020, 0.206], [0.019, 0.021, 0.017]
+[0.002, 0.002, 0.002], [0.045, 0.390, 0.094], [0.449, 0.033, 0.177], [0.354, 0.187, 0.033], [0.211, 0.169, 0.269], [0.257, 0.498, 0.219], [0.193, 0.094, 0.016], [0.116, 0.016, 0.017], [0.553, 0.528, 0.390], [0.495, 0.407, 0.420], [0.371, 0.263, 0.133], [0.354, 0.164, 0.400], [0.325, 0.518, 0.293], [0.452, 0.439, 0.513], [0.349, 0.548, 0.337], [0.152, 0.171, 0.138], [0.729, 0.703, 0.653], [0.407, 0.543, 0.608], [1.682, 1.511, 1.044], [0.024, 0.125, 0.006], [1.291, 0.834, 0.170], [0.344, 0.348, 0.409], [1.214, 0.824, 0.512], [61.878, 12.908, 0.357], [0.311, 0.117, 0.120], [0.297, 0.100, 0.116], [0.135, 0.126, 0.133], [0.869, 0.414, 0.406], [2.413, 2.028, 1.689], [0.043, 0.192, 0.232], [0.428, 0.287, 0.459], [0.392, 0.735, 0.334], [1.965, 1.602, 1.572], [1.449, 1.094, 1.251], [1.256, 1.246, 1.233], [0.103, 0.139, 0.101], [0.059, 0.247, 0.181], [0.027, 0.028, 0.030], [0.173, 0.157, 0.027], [0.233, 0.112, 0.149], [0.021, 0.359, 0.018], [0.197, 0.022, 0.023], [0.014, 0.014, 0.014]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.32.json b/clickhouse-cloud/results/gcp.3.32.json
index e236d6e26..99f49a851 100644
--- a/clickhouse-cloud/results/gcp.3.32.json
+++ b/clickhouse-cloud/results/gcp.3.32.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 32GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 158.944,
- "data_size": 9943604442,
+ "load_time": 171.857,
+ "data_size": 9945453068,
"result": [
-[0.015, 0.003, 0.002], [1.367, 0.110, 0.061], [1.061, 0.797, 0.064], [0.699, 0.456, 0.129], [0.545, 1.126, 1.145], [1.443, 1.110, 0.928], [0.019, 0.153, 0.096], [0.184, 0.021, 0.119], [1.062, 1.084, 1.059], [1.316, 0.775, 0.734], [0.306, 0.375, 0.237], [0.344, 0.271, 0.257], [0.809, 0.972, 1.071], [1.767, 1.199, 1.315], [1.288, 1.160, 1.190], [1.122, 0.929, 0.658], [2.645, 2.483, 3.249], [2.781, 1.813, 2.022], [5.783, 4.576, 6.655], [0.159, 0.039, 0.008], [1.538, 6.314, 4.147], [1.347, 1.558, 0.198], [6.502, 3.998, 0.757], [1.159, 43.459, 0.949], [0.458, 0.491, 0.379], [0.301, 0.276, 0.281], [0.474, 0.380, 0.397], [1.274, 1.305, 1.413], [17.438, 17.983, 16.878], [0.080, 0.206, 0.057], [1.217, 0.738, 0.802], [2.886, 1.920, 1.144], [5.442, 4.162, 7.879], [8.185, 4.096, 7.535], [4.274, 3.985, 4.120], [0.837, 0.535, 0.731], [0.472, 0.204, 0.072], [0.257, 0.213, 0.043], [0.222, 0.117, 0.041], [0.402, 0.098, 0.115], [0.340, 0.023, 0.130], [0.021, 0.293, 0.025], [0.204, 0.026, 0.022]
+[0.003, 0.002, 0.003], [0.447, 0.323, 0.025], [0.504, 0.139, 0.066], [0.586, 0.212, 0.136], [0.786, 0.543, 0.501], [1.251, 1.062, 0.765], [0.019, 0.019, 0.140], [0.164, 0.019, 0.020], [0.831, 0.812, 0.644], [0.930, 1.204, 0.985], [0.358, 0.368, 0.232], [0.413, 0.322, 0.277], [1.036, 1.182, 0.850], [1.527, 1.650, 1.307], [1.137, 0.789, 1.342], [0.902, 0.675, 0.590], [3.055, 2.532, 2.256], [1.544, 1.360, 1.166], [6.101, 5.511, 4.428], [0.403, 0.012, 0.036], [6.292, 4.934, 0.537], [1.616, 0.138, 1.376], [7.174, 0.768, 5.696], [53.184, 1.728, 49.348], [0.379, 0.423, 0.424], [0.298, 0.327, 0.256], [0.369, 0.364, 0.377], [1.509, 1.258, 1.277], [12.759, 8.089, 13.436], [0.335, 0.064, 0.059], [1.636, 1.337, 0.809], [3.053, 1.034, 2.101], [3.840, 6.401, 3.378], [7.645, 6.307, 3.981], [3.858, 3.954, 4.435], [0.507, 0.506, 0.528], [0.330, 0.063, 0.078], [0.039, 0.330, 0.184], [0.199, 0.039, 0.143], [0.123, 0.247, 0.123], [0.022, 0.321, 0.020], [0.295, 0.023, 0.024], [0.021, 0.289, 0.134]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.64.json b/clickhouse-cloud/results/gcp.3.64.json
index c5ce5da21..4f28ccbaf 100644
--- a/clickhouse-cloud/results/gcp.3.64.json
+++ b/clickhouse-cloud/results/gcp.3.64.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 64GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 86.005,
- "data_size": 9946960904,
+ "load_time": 78.906,
+ "data_size": 9948887826,
"result": [
-[0.002, 0.004, 0.002], [0.337, 0.092, 0.018], [0.360, 0.047, 0.046], [0.358, 0.061, 0.054], [0.428, 0.287, 0.383], [0.692, 0.594, 0.456], [0.190, 0.110, 0.016], [0.113, 0.014, 0.148], [0.522, 0.492, 0.392], [0.826, 0.669, 0.577], [0.201, 0.301, 0.264], [0.314, 0.252, 0.206], [0.530, 0.505, 0.462], [0.666, 0.629, 0.672], [0.911, 0.837, 0.804], [0.437, 0.378, 0.445], [1.485, 1.446, 1.347], [0.963, 0.996, 0.930], [3.494, 2.771, 3.557], [0.029, 0.008, 0.101], [3.047, 1.836, 0.337], [0.808, 0.785, 0.761], [3.236, 2.089, 0.450], [39.098, 36.014, 0.565], [0.270, 0.229, 0.228], [0.181, 0.168, 0.169], [0.223, 0.228, 0.248], [0.757, 0.703, 0.672], [9.304, 9.021, 7.696], [0.048, 0.054, 0.049], [0.760, 0.670, 0.538], [1.664, 0.631, 0.571], [3.626, 2.194, 2.235], [2.270, 2.223, 2.097], [2.225, 2.418, 2.101], [0.335, 0.726, 0.489], [0.654, 0.076, 0.227], [0.042, 0.368, 0.155], [0.046, 0.039, 0.181], [0.102, 0.404, 0.107], [0.196, 0.025, 0.025], [0.236, 0.023, 0.107], [0.020, 0.314, 0.018]
+[0.003, 0.002, 0.003], [0.021, 0.320, 0.090], [0.045, 0.387, 0.102], [0.062, 0.297, 0.063], [0.495, 0.352, 0.388], [0.499, 0.530, 0.770], [0.162, 0.014, 0.016], [0.016, 0.150, 0.104], [0.651, 0.394, 0.557], [0.596, 0.603, 0.594], [0.359, 0.260, 0.178], [0.217, 0.384, 0.194], [0.672, 0.666, 0.556], [0.726, 0.819, 0.794], [0.765, 0.780, 0.597], [0.339, 0.361, 0.279], [1.408, 1.287, 1.248], [0.805, 0.617, 1.359], [3.237, 2.475, 2.376], [0.295, 0.026, 0.007], [3.363, 1.939, 0.350], [0.853, 0.942, 0.102], [3.235, 1.989, 0.865], [38.407, 0.603, 0.551], [0.251, 0.237, 0.743], [0.189, 0.157, 0.154], [0.241, 0.235, 0.228], [0.780, 0.750, 0.648], [6.690, 6.072, 4.536], [0.058, 0.210, 0.243], [0.767, 0.443, 0.420], [1.674, 0.640, 1.286], [2.930, 2.305, 2.460], [2.186, 2.032, 2.405], [2.207, 2.226, 2.167], [0.256, 0.297, 0.249], [0.194, 0.314, 0.072], [0.040, 0.049, 0.043], [0.171, 0.171, 0.037], [0.104, 0.279, 0.112], [0.022, 0.024, 0.028], [0.330, 0.182, 0.024], [0.014, 0.017, 0.014]
]
}
diff --git a/clickhouse-cloud/results/gcp.3.8.json b/clickhouse-cloud/results/gcp.3.8.json
index 1f6509fed..c5f99113c 100644
--- a/clickhouse-cloud/results/gcp.3.8.json
+++ b/clickhouse-cloud/results/gcp.3.8.json
@@ -1,7 +1,7 @@
{
"system": "ClickHouse ☁️ (gcp)",
- "date": "2025-10-09",
+ "date": "2025-10-17",
"machine": "ClickHouse ☁️: 8GiB",
"cluster_size": 3,
"proprietary": "yes",
@@ -10,11 +10,11 @@
"tags": ["C++", "column-oriented", "ClickHouse derivative", "managed", "gcp"],
- "load_time": 627.889,
- "data_size": 9944531331,
+ "load_time": 612.424,
+ "data_size": 9947940749,
"result": [
-[0.003, 0.027, 0.003], [0.499, 0.648, 0.047], [0.656, 0.421, 0.266], [1.187, 1.054, 0.926], [2.038, 1.921, 2.222], [8.109, 7.408, 4.338], [0.089, 0.069, 0.372], [0.138, 0.135, 0.073], [3.636, 3.857, 2.122], [3.961, 6.220, 5.082], [1.130, 0.838, 0.596], [1.254, 1.031, 1.062], [5.513, 3.315, 5.279], [8.276, 14.217, 5.993], [8.192, 4.377, 3.542], [2.382, 3.180, 4.134], [27.931, 12.923, 17.821], [13.417, 14.065, 13.347], [30.178, 45.897, 26.614], [0.136, 0.237, 0.197], [25.375, 1.892, 26.070], [6.361, 0.609, 0.598], [7.233, 3.164, 3.175], [46.341, 41.990, 6.414], [1.914, 1.590, 1.701], [0.911, 1.051, 1.007], [1.318, 1.469, 1.352], [4.979, 4.183, 5.651], [71.634, 89.189, 71.953], [0.318, 0.238, 0.146], [3.571, 3.174, 4.206], [4.594, 10.857, 11.199], [33.915, 33.476, 31.702], [26.368, 21.748, 21.364], [24.940, 22.117, 25.403], [1.635, 1.596, 1.649], [0.320, 0.224, 0.180], [0.074, 0.345, 0.196], [0.124, 0.085, 0.067], [0.308, 0.463, 0.386], [0.209, 0.040, 0.177], [0.159, 0.024, 0.210], [0.027, 0.030, 0.022]
+[0.002, 0.003, 0.003], [0.457, 0.140, 0.048], [0.399, 0.702, 0.222], [1.032, 0.805, 0.277], [1.742, 1.943, 1.931], [3.672, 6.606, 2.941], [0.188, 0.131, 0.040], [0.050, 0.138, 0.033], [5.592, 5.337, 2.913], [5.562, 4.861, 3.912], [0.851, 0.957, 0.610], [1.236, 0.901, 0.721], [2.827, 3.411, 2.805], [5.113, 5.424, 6.959], [3.508, 4.317, 3.484], [2.234, 2.206, 2.210], [11.148, 9.221, 11.570], [5.565, 9.773, 5.028], [24.458, 20.803, 20.831], [0.078, 0.339, 0.011], [25.850, 5.087, 25.849], [5.280, 5.407, 0.503], [24.859, 2.893, 2.762], [2.803, 2.634, 2.623], [1.366, 1.387, 1.429], [0.968, 0.967, 0.904], [2.720, 1.600, 1.456], [4.824, 4.564, 4.976], [50.587, 48.939, 33.159], [0.461, 0.246, 0.155], [3.092, 2.731, 2.650], [3.525, 3.270, 3.241], [40.381, 29.801, 26.147], [26.079, 24.805, 26.741], [25.225, 23.980, 22.397], [1.276, 1.276, 1.649], [0.403, 0.142, 0.169], [0.451, 0.416, 0.070], [0.204, 0.063, 0.074], [0.314, 0.526, 0.494], [0.201, 0.127, 0.042], [0.332, 0.023, 0.024], [0.023, 0.024, 0.020]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c6a.2xlarge.json b/clickhouse-datalake-partitioned/results/c6a.2xlarge.json
index d7b7a3d6c..5b827ab07 100644
--- a/clickhouse-datalake-partitioned/results/c6a.2xlarge.json
+++ b/clickhouse-datalake-partitioned/results/c6a.2xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.499, 0.035, 0.038],
- [1.19, 0.066, 0.063],
- [1.592, 0.129, 0.128],
- [1.613, 0.113, 0.144],
- [0.597, 0.605, 0.604],
- [1.018, 0.904, 0.922],
- [1.269, 0.067, 0.068],
- [0.069, 0.068, 0.068],
- [1.372, 0.707, 0.703],
- [0.933, 0.875, 0.874],
- [0.351, 0.267, 0.266],
- [0.394, 0.304, 0.301],
- [0.922, 0.93, 0.917],
- [1.406, 1.392, 1.353],
- [1.09, 1.086, 1.082],
- [0.73, 0.728, 0.732],
- [2.689, 2.709, 2.695],
- [1.756, 1.76, 1.748],
- [5.85, 4.98, 4.971],
- [0.128, 0.107, 0.107],
- [4.993, 1.216, 1.211],
- [2.282, 1.456, 1.457],
- [8.032, 3.743, 2.739],
- [18.691, 17.494, 17.781],
- [1.612, 0.52, 0.523],
- [0.346, 0.345, 0.353],
- [0.526, 0.52, 0.52],
- [3.991, 1.493, 1.466],
- [11.167, 10.519, 10.505],
- [0.951, 0.099, 0.095],
- [2.74, 1.007, 0.984],
- [3.205, 1.357, 1.346],
- [12.518, 15.834, 13.179],
- [5.396, 4.231, 4.374],
- [4.239, 4.354, 10.651],
- [0.683, 0.438, 0.434],
- [0.339, 0.146, 0.148],
- [0.209, 0.09, 0.093],
- [0.13, 0.071, 0.076],
- [0.336, 0.213, 0.221],
- [0.129, 0.061, 0.058],
- [0.082, 0.055, 0.054],
- [0.053, 0.05, 0.051]
+ [0.459, 0.032, 0.037],
+ [1.2, 0.07, 0.072],
+ [1.597, 0.131, 0.134],
+ [1.622, 0.117, 0.124],
+ [0.629, 0.647, 0.647],
+ [1.288, 0.885, 0.894],
+ [1.335, 0.076, 0.073],
+ [0.068, 0.071, 0.071],
+ [1.394, 0.746, 0.736],
+ [0.991, 0.889, 0.901],
+ [0.335, 0.238, 0.247],
+ [0.373, 0.268, 0.267],
+ [0.924, 0.921, 0.947],
+ [1.353, 1.356, 1.359],
+ [1.083, 1.057, 1.067],
+ [0.749, 0.755, 0.743],
+ [2.788, 2.777, 2.794],
+ [1.785, 1.773, 1.805],
+ [5.977, 5.175, 5.148],
+ [0.115, 0.11, 0.109],
+ [5.446, 1.186, 1.148],
+ [2.044, 1.388, 1.343],
+ [9.053, 8.455, 6.062],
+ [19.899, 19.439, 19.522],
+ [1.37, 0.508, 0.501],
+ [0.327, 0.325, 0.32],
+ [0.509, 0.496, 0.497],
+ [2.972, 1.116, 1.125],
+ [11.427, 10.558, 10.533],
+ [1.046, 0.1, 0.099],
+ [2.871, 0.802, 0.804],
+ [3.259, 1.363, 1.251],
+ [13.382, 12.576, null],
+ [5.423, 11.796, 4.35],
+ [11.76, 4.406, 11.293],
+ [0.709, 0.528, 0.559],
+ [0.208, 0.143, 0.141],
+ [0.202, 0.093, 0.093],
+ [0.119, 0.072, 0.078],
+ [0.238, 0.221, 0.202],
+ [0.13, 0.057, 0.051],
+ [0.075, 0.051, 0.049],
+ [0.053, 0.049, 0.109]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c6a.4xlarge.json b/clickhouse-datalake-partitioned/results/c6a.4xlarge.json
index 0244fe18b..ce36ec63d 100644
--- a/clickhouse-datalake-partitioned/results/c6a.4xlarge.json
+++ b/clickhouse-datalake-partitioned/results/c6a.4xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.69, 0.041, 0.036],
- [2.096, 0.057, 0.059],
- [2.114, 0.105, 0.107],
- [2.146, 0.116, 0.118],
- [0.435, 0.437, 0.433],
- [0.822, 0.569, 0.548],
- [0.846, 0.069, 0.059],
- [0.056, 0.064, 0.057],
- [0.847, 0.53, 0.557],
- [0.7, 0.645, 0.644],
- [0.301, 0.233, 0.226],
- [0.273, 0.229, 0.241],
- [0.703, 0.681, 0.688],
- [0.993, 0.956, 0.975],
- [0.787, 0.764, 0.76],
- [0.518, 0.583, 0.643],
- [2.524, 2.183, 2.194],
- [1.576, 1.387, 1.621],
- [4.876, 4.279, 4.011],
- [0.12, 0.115, 0.112],
- [5.05, 1.223, 1.191],
- [1.556, 1.502, 1.496],
- [4.898, 3.176, 3.287],
- [10.31, 5.834, 2.829],
- [0.384, 0.373, 0.377],
- [0.275, 0.275, 0.299],
- [0.376, 0.384, 0.389],
- [1.63, 1.618, 1.672],
- [5.459, 5.483, 5.585],
- [0.12, 0.077, 0.085],
- [0.628, 0.639, 0.631],
- [1.025, 1.037, 1.048],
- [4.823, 4.767, 4.65],
- [3.146, 3.103, 3.145],
- [3.048, 3.122, 3.05],
- [0.368, 0.37, 0.36],
- [0.147, 0.181, 0.156],
- [0.094, 0.098, 0.103],
- [0.084, 0.087, 0.086],
- [0.22, 0.217, 0.21],
- [0.057, 0.071, 0.066],
- [0.068, 0.057, 0.062],
- [0.058, 0.061, 0.052]
+ [0.952, 0.04, 0.045],
+ [2.139, 0.057, 0.065],
+ [1.991, 0.103, 0.118],
+ [2.16, 0.114, 0.116],
+ [0.426, 0.43, 0.436],
+ [1.103, 0.539, 0.533],
+ [0.856, 0.063, 0.082],
+ [0.056, 0.06, 0.06],
+ [0.879, 0.552, 0.541],
+ [0.68, 0.661, 0.653],
+ [0.29, 0.221, 0.221],
+ [0.313, 0.243, 0.241],
+ [0.671, 0.681, 0.69],
+ [0.989, 0.98, 0.993],
+ [0.758, 0.748, 0.748],
+ [0.522, 0.517, 0.525],
+ [1.859, 1.853, 1.853],
+ [1.153, 1.29, 1.152],
+ [4.412, 3.798, 3.827],
+ [0.105, 0.099, 0.104],
+ [2.846, 1.13, 1.145],
+ [1.417, 1.365, 1.362],
+ [3.548, 2.477, 2.467],
+ [10.856, 11.016, 10.847],
+ [0.548, 0.386, 0.376],
+ [0.28, 0.286, 0.278],
+ [0.387, 0.377, 0.4],
+ [1.542, 1.112, 1.121],
+ [5.832, 5.492, 5.54],
+ [0.25, 0.084, 0.083],
+ [1.021, 0.647, 0.66],
+ [1.491, 1.114, 1.111],
+ [4.546, 4.535, 4.622],
+ [3.374, 3.084, 3.123],
+ [3.109, 3.076, 3.116],
+ [0.365, 0.366, 0.369],
+ [0.164, 0.153, 0.135],
+ [0.097, 0.098, 0.1],
+ [0.118, 0.079, 0.074],
+ [0.234, 0.211, 0.207],
+ [0.113, 0.066, 0.058],
+ [0.083, 0.062, 0.054],
+ [0.056, 0.058, 0.071]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c6a.large.json b/clickhouse-datalake-partitioned/results/c6a.large.json
index 4c4c7115c..e2b6716c4 100644
--- a/clickhouse-datalake-partitioned/results/c6a.large.json
+++ b/clickhouse-datalake-partitioned/results/c6a.large.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.large",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [1.223, 0.052, 0.055],
- [3.46, 0.141, 0.138],
- [5.261, 0.377, 0.392],
- [4.636, 0.269, 0.276],
- [1.803, 1.813, 1.848],
- [3.958, 3.215, 3.208],
- [3.966, 0.149, 0.153],
- [0.428, 0.143, 0.148],
- [5.028, 2.323, 2.327],
- [3.746, 2.928, 2.914],
- [1.345, 0.846, 0.843],
- [1.379, 0.978, 0.983],
- [3.262, 3.159, 3.11],
- [7.373, 7.333, 7.337],
- [4.015, 6.697, 3.859],
- [1.979, 1.975, 1.98],
- [12.878, 12.678, 12.934],
- [9.505, 9.692, 9.65],
- [32.379, 29.486, 32.324],
- [0.259, 0.238, 0.249],
- [18.713, 16.341, 15.024],
- [19.241, 18.644, 18.038],
- [39.48, 39.202, 39.495],
- [83.009, 83.122, 83.157],
- [10.552, 3.413, 1.879],
- [1.247, 1.259, 1.246],
- [1.862, 1.904, 1.888],
- [21.258, 18.456, 17.683],
- [48.135, 45.929, 44.736],
- [4.837, 0.234, 0.233],
- [15.302, 9.027, 3.802],
- [18.171, 13.416, 13.323],
+ [1.283, 0.056, 0.066],
+ [3.515, 0.142, 0.141],
+ [5.318, 0.363, 0.363],
+ [4.716, 0.271, 0.265],
+ [1.825, 1.832, 1.846],
+ [3.822, 3.05, 3.054],
+ [4.062, 0.151, 0.164],
+ [0.415, 0.145, 0.148],
+ [5.16, 2.369, 2.375],
+ [4.176, 2.96, 2.938],
+ [1.11, 0.705, 0.693],
+ [1.269, 0.822, 0.83],
+ [3.003, 2.936, 2.946],
+ [6.984, 6.843, 6.809],
+ [3.788, 3.522, 3.544],
+ [2.012, 2.005, 1.987],
+ [12.042, 11.629, 11.873],
+ [9.039, 9.067, 9.137],
+ [29.872, 39.124, 35.283],
+ [0.268, 0.242, 0.242],
+ [18.923, 19.569, 18.306],
+ [20.011, 19.704, 19.524],
+ [38.477, 38.561, 38.854],
+ [87.488, 86.114, 84.587],
+ [8.51, 1.635, 1.629],
+ [1.018, 1.025, 1.021],
+ [1.642, 1.635, 1.639],
+ [21.857, 21.598, 21.014],
+ [45.728, 45.496, 45.064],
+ [4.259, 0.247, 0.248],
+ [15.821, 7.366, 2.576],
+ [18.014, 15.918, 15.412],
[null, null, null],
- [165.402, null, null],
- [null, 302.897, null],
- [9.88, 1.345, 1.607],
- [0.82, 0.291, 0.281],
- [0.366, 0.164, 0.163],
- [0.464, 0.118, 0.117],
- [0.715, 0.454, 0.428],
- [0.314, 0.093, 0.091],
- [0.152, 0.084, 0.088],
- [0.085, 0.08, 0.082]
+ [null, 73.869, null],
+ [354.51, null, null],
+ [16.551, 1.384, 1.408],
+ [0.802, 0.298, 0.248],
+ [0.324, 0.154, 0.149],
+ [0.225, 0.121, 0.117],
+ [0.9, 0.371, 0.379],
+ [0.329, 0.115, 0.092],
+ [0.095, 0.092, 0.086],
+ [0.133, 0.083, 0.087]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c6a.metal.json b/clickhouse-datalake-partitioned/results/c6a.metal.json
index ba04e4600..1f9107b6a 100644
--- a/clickhouse-datalake-partitioned/results/c6a.metal.json
+++ b/clickhouse-datalake-partitioned/results/c6a.metal.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.142, 0.067, 0.07],
- [0.285, 0.086, 0.086],
- [0.377, 0.126, 0.108],
- [0.357, 0.117, 0.117],
- [0.282, 0.298, 0.284],
- [0.403, 0.285, 0.287],
- [0.35, 0.082, 0.091],
- [0.095, 0.092, 0.09],
- [0.574, 0.398, 0.399],
- [0.535, 0.416, 0.491],
- [0.257, 0.207, 0.217],
- [0.262, 0.201, 0.205],
- [0.28, 0.299, 0.262],
- [0.301, 0.316, 0.325],
- [0.344, 0.294, 0.286],
- [0.245, 0.219, 0.218],
- [0.504, 0.513, 0.539],
- [0.428, 0.449, 0.44],
- [1.162, 0.862, 0.882],
- [0.127, 0.119, 0.12],
- [2.16, 0.428, 0.476],
- [0.515, 0.518, 0.497],
- [1.853, 0.652, 0.719],
- [6.098, 0.764, 0.846],
- [0.2, 0.19, 0.187],
- [0.166, 0.186, 0.159],
- [0.193, 0.177, 0.196],
- [0.572, 0.55, 0.612],
- [1.448, 1.478, 1.441],
- [0.133, 0.112, 0.129],
- [0.255, 0.249, 0.228],
- [0.308, 0.346, 0.32],
- [1.314, 1.187, 1.206],
- [0.846, 0.903, 0.784],
- [0.862, 0.797, 0.767],
- [0.194, 0.171, 0.201],
- [0.184, 0.187, 0.178],
- [0.141, 0.145, 0.142],
- [0.102, 0.107, 0.122],
- [0.196, 0.221, 0.201],
- [0.101, 0.106, 0.099],
- [0.093, 0.093, 0.093],
- [0.092, 0.092, 0.093]
+ [0.179, 0.076, 0.059],
+ [0.324, 0.096, 0.101],
+ [0.374, 0.139, 0.137],
+ [0.349, 0.139, 0.125],
+ [0.305, 0.293, 0.298],
+ [0.497, 0.28, 0.292],
+ [0.334, 0.101, 0.1],
+ [0.11, 0.116, 0.096],
+ [0.6, 0.433, 0.409],
+ [0.526, 0.465, 0.441],
+ [0.321, 0.226, 0.22],
+ [0.267, 0.219, 0.202],
+ [0.306, 0.318, 0.298],
+ [0.332, 0.328, 0.358],
+ [0.354, 0.354, 0.299],
+ [0.234, 0.24, 0.231],
+ [0.499, 0.534, 0.496],
+ [0.419, 0.418, 0.421],
+ [1.165, 0.888, 0.9],
+ [0.128, 0.133, 0.139],
+ [3.28, 0.437, 0.411],
+ [0.464, 0.451, 0.475],
+ [2.415, 0.673, 0.682],
+ [6.09, 0.847, 0.824],
+ [0.192, 0.184, 0.204],
+ [0.183, 0.166, 0.179],
+ [0.199, 0.199, 0.191],
+ [0.393, 0.397, 0.397],
+ [1.489, 1.51, 1.407],
+ [0.129, 0.137, 0.126],
+ [0.258, 0.273, 0.273],
+ [0.401, 0.372, 0.38],
+ [1.312, 1.351, 1.339],
+ [0.875, 0.882, 0.896],
+ [0.867, 0.92, 0.87],
+ [0.198, 0.194, 0.2],
+ [0.166, 0.183, 0.172],
+ [0.142, 0.149, 0.146],
+ [0.118, 0.102, 0.116],
+ [0.222, 0.208, 0.218],
+ [0.105, 0.102, 0.106],
+ [0.093, 0.105, 0.088],
+ [0.086, 0.093, 0.086]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c6a.xlarge.json b/clickhouse-datalake-partitioned/results/c6a.xlarge.json
index 32b25d24f..2fbf2d95d 100644
--- a/clickhouse-datalake-partitioned/results/c6a.xlarge.json
+++ b/clickhouse-datalake-partitioned/results/c6a.xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.633, 0.039, 0.038],
- [1.873, 0.084, 0.083],
- [2.922, 0.202, 0.199],
- [2.398, 0.15, 0.15],
- [0.926, 0.935, 0.933],
- [1.81, 1.61, 1.612],
- [2.177, 0.089, 0.088],
- [0.088, 0.088, 0.087],
- [2.59, 1.228, 1.236],
- [1.721, 1.53, 1.529],
- [0.661, 0.45, 0.447],
- [0.7, 0.518, 0.513],
- [1.644, 1.644, 1.657],
- [2.442, 2.451, 2.463],
- [1.916, 1.844, 1.853],
- [1.046, 1.054, 1.06],
- [6.699, 6.611, 6.71],
- [4.988, 5.103, 5.167],
- [15.564, 13.535, 13.685],
- [0.138, 0.139, 0.146],
- [10.39, 8.881, 8.426],
- [8.755, 5.526, 2.763],
- [16.43, 16.362, 16.516],
- [42.21, 40.341, 39.985],
- [4.43, 0.949, 0.952],
- [0.627, 0.628, 0.633],
- [0.953, 0.952, 0.953],
- [9.755, 6.945, 4.336],
- [22.657, 21.499, 20.574],
- [2.29, 0.137, 0.136],
- [7.305, 1.798, 1.79],
- [7.309, 4.809, 2.645],
- [38.29, 22.414, 28.104],
- [18.571, 19.012, 27.018],
- [22.349, 16.614, 20.563],
- [2.408, 0.837, 0.841],
- [0.412, 0.173, 0.16],
- [0.197, 0.095, 0.113],
- [0.11, 0.077, 0.08],
- [0.422, 0.259, 0.248],
- [0.154, 0.064, 0.068],
- [0.083, 0.056, 0.059],
- [0.058, 0.057, 0.054]
+ [0.708, 0.042, 0.044],
+ [1.946, 0.086, 0.085],
+ [3.004, 0.204, 0.206],
+ [2.488, 0.163, 0.16],
+ [0.963, 0.951, 0.97],
+ [1.755, 1.576, 1.564],
+ [2.368, 0.091, 0.095],
+ [0.088, 0.089, 0.092],
+ [2.632, 1.279, 1.272],
+ [1.745, 1.575, 1.565],
+ [0.581, 0.377, 0.378],
+ [0.628, 0.444, 0.468],
+ [1.567, 1.563, 1.576],
+ [2.389, 2.378, 2.395],
+ [1.812, 1.765, 1.757],
+ [1.054, 1.06, 1.061],
+ [6.662, 6.693, 6.652],
+ [4.958, 4.882, 2.838],
+ [15.363, 13.204, 13.17],
+ [0.148, 0.146, 0.15],
+ [10.612, 10.148, 9.731],
+ [10.811, 10.867, 10.627],
+ [20.216, 20.189, 20.272],
+ [45.724, 45.59, 44.272],
+ [4.763, 0.878, 0.863],
+ [0.556, 0.554, 0.544],
+ [0.87, 0.883, 0.863],
+ [11.745, 11.015, 11.035],
+ [23.144, 22.12, 20.743],
+ [2.083, 0.143, 0.141],
+ [7.908, 1.361, 1.34],
+ [7.609, 2.392, 2.184],
+ [30.053, 21.272, 32.067],
+ [21.834, 20.916, 19.542],
+ [18.983, 20.557, 25.338],
+ [2.417, 0.869, 0.858],
+ [0.42, 0.163, 0.156],
+ [0.205, 0.102, 0.101],
+ [0.107, 0.086, 0.077],
+ [0.365, 0.238, 0.239],
+ [0.126, 0.063, 0.066],
+ [0.092, 0.059, 0.061],
+ [0.062, 0.058, 0.059]
]
}
diff --git a/clickhouse-datalake-partitioned/results/c7a.metal-48xl.json b/clickhouse-datalake-partitioned/results/c7a.metal-48xl.json
index 9233bc94f..efcb6d939 100644
--- a/clickhouse-datalake-partitioned/results/c7a.metal-48xl.json
+++ b/clickhouse-datalake-partitioned/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-30",
+ "system": "ClickHouse (data lake, partitioned)",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.527, 0.086, 0.076],
- [1.148, 0.103, 0.096],
- [1.318, 0.121, 0.131],
- [1.294, 0.116, 0.125],
- [0.46, 0.441, 0.44],
- [1.242, 0.47, 0.464],
- [0.652, 0.095, 0.095],
- [0.102, 0.103, 0.108],
- [0.847, 0.409, 0.403],
- [0.585, 0.417, 0.424],
- [0.379, 0.224, 0.225],
- [0.295, 0.207, 0.235],
- [0.299, 0.299, 0.267],
- [0.324, 0.339, 0.384],
- [0.295, 0.285, 0.275],
- [0.226, 0.243, 0.214],
- [0.461, 0.389, 0.398],
- [0.363, 0.381, 0.416],
- [1.609, 0.791, 0.802],
- [0.123, 0.118, 0.116],
- [5.569, 0.45, 0.395],
- [0.847, 0.476, 0.485],
- [2.786, 0.586, 0.584],
- [8.015, 0.95, 0.76],
- [0.193, 0.225, 0.206],
- [0.188, 0.185, 0.18],
- [0.197, 0.199, 0.185],
- [0.489, 0.571, 0.494],
- [1.153, 1.249, 1.197],
- [0.137, 0.144, 0.15],
- [0.258, 0.245, 0.244],
- [0.345, 0.278, 0.284],
- [0.915, 0.886, 0.982],
- [0.689, 0.672, 0.701],
- [0.699, 0.736, 0.776],
- [0.213, 0.203, 0.213],
- [0.177, 0.193, 0.18],
- [0.153, 0.141, 0.153],
- [0.138, 0.118, 0.117],
- [0.208, 0.212, 0.2],
- [0.124, 0.112, 0.121],
- [0.122, 0.108, 0.123],
- [0.105, 0.099, 0.103]
+ [0.164, 0.082, 0.099],
+ [0.31, 0.113, 0.119],
+ [0.412, 0.15, 0.126],
+ [0.343, 0.134, 0.141],
+ [0.493, 0.468, 0.477],
+ [0.626, 0.474, 0.517],
+ [0.321, 0.12, 0.117],
+ [0.111, 0.109, 0.113],
+ [0.583, 0.409, 0.434],
+ [0.504, 0.451, 0.454],
+ [0.281, 0.24, 0.249],
+ [0.276, 0.221, 0.227],
+ [0.312, 0.297, 0.287],
+ [0.37, 0.366, 0.325],
+ [0.311, 0.28, 0.279],
+ [0.253, 0.244, 0.235],
+ [0.439, 0.411, 0.41],
+ [0.374, 0.411, 0.379],
+ [0.964, 0.691, 0.71],
+ [0.136, 0.124, 0.128],
+ [1.864, 0.493, 0.463],
+ [0.587, 0.525, 0.538],
+ [1.326, 0.636, 0.563],
+ [3.804, 0.728, 0.676],
+ [0.216, 0.201, 0.2],
+ [0.207, 0.191, 0.222],
+ [0.205, 0.205, 0.184],
+ [0.425, 0.362, 0.432],
+ [1.159, 1.368, 1.209],
+ [0.142, 0.143, 0.144],
+ [0.266, 0.278, 0.261],
+ [0.367, 0.361, 0.372],
+ [0.856, 0.902, 0.906],
+ [0.733, 0.757, 0.689],
+ [0.832, 0.7, 0.681],
+ [0.212, 0.211, 0.223],
+ [0.216, 0.199, 0.215],
+ [0.162, 0.154, 0.152],
+ [0.125, 0.129, 0.127],
+ [0.202, 0.257, 0.226],
+ [0.142, 0.115, 0.111],
+ [0.111, 0.118, 0.122],
+ [0.108, 0.119, 0.109]
]
}
+
diff --git a/clickhouse-datalake-partitioned/results/c8g.4xlarge.json b/clickhouse-datalake-partitioned/results/c8g.4xlarge.json
index 75a725158..aed44ac4e 100644
--- a/clickhouse-datalake-partitioned/results/c8g.4xlarge.json
+++ b/clickhouse-datalake-partitioned/results/c8g.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-28",
+ "system": "ClickHouse (data lake, partitioned)",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [1.104, 0.032, 0.039],
- [2.845, 0.047, 0.065],
- [2.511, 0.081, 0.081],
- [1.616, 0.069, 0.072],
- [0.215, 0.209, 0.204],
- [1.139, 0.356, 0.367],
- [0.845, 0.05, 0.047],
- [0.055, 0.054, 0.053],
- [0.781, 0.273, 0.274],
- [0.411, 0.345, 0.362],
- [0.265, 0.156, 0.163],
- [0.268, 0.177, 0.173],
- [0.361, 0.358, 0.366],
- [0.502, 0.52, 0.502],
- [0.437, 0.405, 0.408],
- [0.241, 0.245, 0.245],
- [0.884, 0.811, 0.927],
- [0.675, 0.672, 0.575],
- [3.231, 1.571, 1.58],
- [0.067, 0.06, 0.061],
- [4.003, 0.483, 0.468],
- [0.813, 0.623, 0.655],
- [3.626, 0.996, 1.017],
- [12.226, 4.85, 1.283],
- [0.232, 0.221, 0.224],
- [0.165, 0.161, 0.166],
- [0.228, 0.22, 0.228],
- [0.53, 0.491, 0.509],
- [2.955, 2.981, 2.928],
- [0.086, 0.075, 0.067],
- [0.373, 0.366, 0.366],
- [0.489, 0.489, 0.488],
- [1.67, 1.661, 1.677],
- [1.275, 1.295, 1.287],
- [1.309, 1.323, 1.299],
- [0.195, 0.203, 0.206],
- [0.115, 0.116, 0.105],
- [0.085, 0.076, 0.086],
- [0.077, 0.08, 0.062],
- [0.151, 0.158, 0.157],
- [0.064, 0.071, 0.051],
- [0.057, 0.05, 0.056],
- [0.052, 0.053, 0.064]
+ [0.227, 0.038, 0.042],
+ [0.572, 0.051, 0.049],
+ [0.852, 0.082, 0.085],
+ [0.797, 0.068, 0.073],
+ [0.218, 0.223, 0.216],
+ [0.464, 0.354, 0.352],
+ [0.669, 0.051, 0.052],
+ [0.053, 0.056, 0.064],
+ [0.764, 0.293, 0.311],
+ [0.443, 0.352, 0.366],
+ [0.248, 0.154, 0.16],
+ [0.237, 0.178, 0.171],
+ [0.349, 0.362, 0.336],
+ [0.485, 0.473, 0.51],
+ [0.435, 0.41, 0.403],
+ [0.253, 0.25, 0.247],
+ [0.906, 0.896, 0.813],
+ [0.685, 0.565, 0.662],
+ [2.4, 1.642, 1.634],
+ [0.068, 0.071, 0.071],
+ [3.517, 0.542, 0.496],
+ [0.721, 0.627, 0.598],
+ [3.5, 0.995, 1.003],
+ [11.685, 10.979, 10.414],
+ [0.511, 0.228, 0.219],
+ [0.158, 0.157, 0.155],
+ [0.221, 0.245, 0.226],
+ [1.336, 0.48, 0.447],
+ [3.541, 3.064, 2.99],
+ [0.219, 0.077, 0.081],
+ [0.912, 0.324, 0.343],
+ [1.182, 0.447, 0.457],
+ [1.762, 1.744, 1.766],
+ [1.689, 1.314, 1.31],
+ [1.301, 1.318, 1.289],
+ [0.201, 0.221, 0.216],
+ [0.144, 0.103, 0.108],
+ [0.175, 0.08, 0.078],
+ [0.142, 0.065, 0.062],
+ [0.191, 0.163, 0.16],
+ [0.157, 0.049, 0.046],
+ [0.063, 0.044, 0.049],
+ [0.045, 0.044, 0.051]
]
}
+
diff --git a/clickhouse-datalake-partitioned/results/c8g.metal-48xl.json b/clickhouse-datalake-partitioned/results/c8g.metal-48xl.json
index d88942fc8..23b9a6ea6 100644
--- a/clickhouse-datalake-partitioned/results/c8g.metal-48xl.json
+++ b/clickhouse-datalake-partitioned/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, partitioned)",
- "date": "2025-08-28",
+ "system": "ClickHouse (data lake, partitioned)",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.287, 0.062, 0.063],
- [0.644, 0.08, 0.083],
- [1.412, 0.087, 0.089],
- [1.334, 0.095, 0.087],
- [0.367, 0.324, 0.282],
- [1.012, 0.302, 0.274],
- [0.55, 0.065, 0.069],
- [0.074, 0.092, 0.082],
- [0.516, 0.294, 0.281],
- [0.551, 0.309, 0.337],
- [0.229, 0.162, 0.162],
- [0.249, 0.135, 0.156],
- [0.224, 0.232, 0.219],
- [0.237, 0.243, 0.233],
- [0.238, 0.206, 0.241],
- [0.16, 0.15, 0.164],
- [0.388, 0.333, 0.392],
- [0.294, 0.378, 0.312],
- [1.451, 0.657, 0.591],
- [0.089, 0.082, 0.083],
- [5.35, 0.381, 0.384],
- [1.023, 0.418, 0.416],
- [3.187, 0.642, 0.668],
- [9.768, 0.946, 0.818],
- [0.151, 0.166, 0.152],
- [0.136, 0.144, 0.145],
- [0.148, 0.144, 0.167],
- [0.42, 0.511, 0.465],
- [1.366, 1.232, 1.224],
- [0.13, 0.135, 0.142],
- [0.196, 0.199, 0.209],
- [0.268, 0.232, 0.261],
- [0.775, 0.768, 0.929],
- [0.641, 0.548, 0.54],
- [0.581, 0.581, 0.637],
- [0.148, 0.143, 0.132],
- [0.139, 0.139, 0.141],
- [0.108, 0.12, 0.123],
- [0.099, 0.099, 0.103],
- [0.189, 0.159, 0.188],
- [0.09, 0.082, 0.088],
- [0.085, 0.088, 0.081],
- [0.088, 0.074, 0.077]
+ [0.168, 0.094, 0.09],
+ [0.32, 0.116, 0.1],
+ [0.432, 0.119, 0.127],
+ [0.384, 0.118, 0.107],
+ [0.333, 0.357, 0.371],
+ [0.487, 0.409, 0.42],
+ [0.338, 0.113, 0.104],
+ [0.115, 0.106, 0.104],
+ [0.495, 0.346, 0.331],
+ [0.411, 0.374, 0.376],
+ [0.296, 0.192, 0.199],
+ [0.244, 0.181, 0.19],
+ [0.226, 0.234, 0.222],
+ [0.298, 0.262, 0.271],
+ [0.286, 0.247, 0.247],
+ [0.224, 0.195, 0.193],
+ [0.372, 0.364, 0.347],
+ [0.338, 0.368, 0.343],
+ [1.04, 0.66, 0.652],
+ [0.112, 0.109, 0.112],
+ [1.68, 0.395, 0.352],
+ [0.471, 0.454, 0.427],
+ [1.329, 0.603, 0.605],
+ [3.788, 1.13, 0.705],
+ [0.175, 0.187, 0.184],
+ [0.162, 0.16, 0.15],
+ [0.181, 0.176, 0.181],
+ [0.38, 0.37, 0.396],
+ [1.318, 1.201, 1.259],
+ [0.158, 0.164, 0.157],
+ [0.239, 0.242, 0.235],
+ [0.313, 0.335, 0.309],
+ [0.85, 0.915, 0.849],
+ [0.71, 0.721, 0.597],
+ [0.697, 0.641, 0.595],
+ [0.169, 0.171, 0.177],
+ [0.175, 0.172, 0.174],
+ [0.125, 0.158, 0.139],
+ [0.125, 0.125, 0.135],
+ [0.214, 0.211, 0.191],
+ [0.109, 0.13, 0.116],
+ [0.11, 0.1, 0.107],
+ [0.117, 0.111, 0.096]
]
}
+
diff --git a/clickhouse-datalake/results/c6a.2xlarge.json b/clickhouse-datalake/results/c6a.2xlarge.json
index ef0766ccd..5327f5f36 100644
--- a/clickhouse-datalake/results/c6a.2xlarge.json
+++ b/clickhouse-datalake/results/c6a.2xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.122, 0.057, 0.059],
- [12.65, 0.104, 0.1],
- [15.076, 0.2, 0.223],
- [18.671, 0.154, 0.168],
- [2.039, 2.047, 2.054],
- [4.675, 3.047, 3.031],
- [5.509, 0.097, 0.099],
- [0.111, 0.091, 0.091],
- [5.63, 2.67, 2.671],
- [3.144, 3.141, 3.141],
- [1.517, 0.309, 0.306],
- [1.535, 0.37, 0.368],
- [4.613, 4.537, 4.513],
- [4.003, 4.067, 4.022],
- [3.005, 2.914, 2.93],
- [2.193, 2.2, 2.234],
- [13.776, 13.652, 13.889],
- [10.835, 11.21, 11.136],
- [31.54, 29.332, 29.318],
- [0.167, 0.145, 0.146],
- [28.136, 1.745, 1.79],
- [6.856, 2.241, 2.261],
- [48.697, 29.142, 4.461],
- [117.911, 110.634, 110.149],
- [6.76, 0.648, 0.642],
- [0.547, 0.548, 0.526],
- [0.652, 0.634, 0.634],
- [18.331, 2.218, 2.247],
- [48.669, 46.947, 48.542],
- [4.467, 0.127, 0.126],
- [13.433, 1.485, 1.526],
- [12.566, 2.817, 2.932],
- [49.804, 51.381, 49.371],
- [29.657, 27.633, 26.789],
- [26.566, 26.442, 25.947],
- [1.571, 1.521, 1.506],
- [0.448, 0.222, 0.229],
- [0.318, 0.127, 0.124],
- [0.16, 0.111, 0.107],
- [0.533, 0.406, 0.413],
- [0.273, 0.092, 0.091],
- [0.115, 0.08, 0.086],
- [0.068, 0.078, 0.077]
+ [0.116, 0.06, 0.059],
+ [13.655, 0.101, 0.098],
+ [14.501, 0.21, 0.234],
+ [15.632, 0.169, 0.173],
+ [2.026, 2.037, 2.05],
+ [3.557, 2.979, 3.019],
+ [5.578, 0.095, 0.097],
+ [0.11, 0.092, 0.1],
+ [5.734, 2.65, 2.674],
+ [3.145, 3.096, 3.121],
+ [1.532, 0.292, 0.282],
+ [1.477, 0.355, 0.352],
+ [4.531, 4.45, 4.484],
+ [3.975, 3.968, 3.945],
+ [3.004, 2.914, 2.952],
+ [2.226, 2.207, 2.218],
+ [13.578, 13.548, 13.715],
+ [10.842, 11.376, 11.458],
+ [32.581, 29.357, 30.223],
+ [0.14, 0.152, 0.154],
+ [28.417, 1.4, 1.366],
+ [9.928, 1.97, 1.966],
+ [51.422, 39.256, 13.007],
+ [119.383, 118.953, 119.965],
+ [3.74, 0.557, 0.557],
+ [0.485, 0.484, 0.491],
+ [0.55, 0.56, 0.554],
+ [8.855, 1.431, 1.414],
+ [46.716, 46.111, 45.702],
+ [4.95, 0.122, 0.119],
+ [14.533, 1.543, 1.56],
+ [15.125, 2.89, 2.852],
+ [42.003, 46.43, 41.883],
+ [24.435, 23.901, 24.168],
+ [24.485, 24.018, 24.064],
+ [1.494, 1.489, 1.498],
+ [0.437, 0.233, 0.23],
+ [0.121, 0.13, 0.126],
+ [0.191, 0.109, 0.109],
+ [0.7, 0.381, 0.374],
+ [0.366, 0.085, 0.091],
+ [0.129, 0.084, 0.061],
+ [0.08, 0.078, 0.073]
]
}
diff --git a/clickhouse-datalake/results/c6a.4xlarge.json b/clickhouse-datalake/results/c6a.4xlarge.json
index e2f513d18..88c455e46 100644
--- a/clickhouse-datalake/results/c6a.4xlarge.json
+++ b/clickhouse-datalake/results/c6a.4xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.234, 0.059, 0.06],
- [15.097, 0.104, 0.1],
- [15.078, 0.23, 0.233],
- [18.605, 0.182, 0.187],
- [2.043, 2.019, 2.055],
- [4.67, 2.991, 3.018],
- [5.547, 0.077, 0.078],
- [0.104, 0.108, 0.109],
- [5.732, 2.68, 2.616],
- [3.184, 3.078, 3.128],
- [1.433, 0.285, 0.278],
- [1.476, 0.351, 0.348],
- [2.837, 2.853, 2.815],
- [3.972, 4.036, 4.023],
- [3.006, 2.906, 2.957],
- [2.205, 2.187, 2.226],
- [9.35, 9.413, 9.405],
- [6.744, 6.851, 6.758],
- [18.737, 17.938, 18.024],
- [0.16, 0.182, 0.16],
- [28.136, 1.581, 1.618],
- [1.885, 1.706, 1.645],
- [33.233, 3.047, 3.043],
- [113.231, 76.424, 9.467],
- [0.451, 0.449, 0.453],
- [0.464, 0.504, 0.457],
- [0.454, 0.441, 0.45],
- [1.662, 1.721, 1.753],
- [44.692, 46.702, 44.444],
- [0.104, 0.104, 0.105],
- [1.347, 1.364, 1.364],
- [2.615, 2.587, 2.607],
- [24.591, 24.692, 24.72],
- [14.033, 14.272, 14.04],
- [14.03, 14.039, 14.034],
- [1.494, 1.496, 1.516],
- [0.219, 0.229, 0.223],
- [0.124, 0.137, 0.129],
- [0.108, 0.107, 0.107],
- [0.38, 0.4, 0.406],
- [0.091, 0.086, 0.084],
- [0.08, 0.08, 0.081],
- [0.077, 0.08, 0.073]
+ [0.139, 0.064, 0.062],
+ [16.549, 0.108, 0.108],
+ [14.457, 0.256, 0.251],
+ [15.561, 0.211, 0.197],
+ [2.317, 2.345, 2.343],
+ [3.535, 3.258, 3.232],
+ [5.511, 0.1, 0.101],
+ [0.103, 0.114, 0.114],
+ [5.773, 2.984, 3.007],
+ [3.485, 3.468, 3.462],
+ [1.519, 0.282, 0.31],
+ [1.481, 0.369, 0.371],
+ [3.173, 3.172, 3.158],
+ [4.618, 4.604, 4.692],
+ [3.517, 3.33, 3.359],
+ [2.434, 2.484, 2.486],
+ [10.899, 10.813, 10.934],
+ [7.764, 7.828, 7.825],
+ [22.282, 21.161, 21.493],
+ [0.191, 0.192, 0.198],
+ [28.571, 1.797, 1.778],
+ [2.135, 1.929, 1.945],
+ [33.405, 3.616, 3.61],
+ [124.771, 124.962, 124.452],
+ [1.16, 0.527, 0.513],
+ [0.54, 0.552, 0.536],
+ [0.532, 0.499, 0.519],
+ [8.535, 1.635, 1.7],
+ [50.083, 45.089, 45.095],
+ [0.128, 0.117, 0.12],
+ [7.812, 1.811, 1.795],
+ [10.087, 3.337, 3.307],
+ [28.9, 28.903, 28.851],
+ [16.012, 15.717, 15.898],
+ [15.716, 15.305, 16.031],
+ [1.659, 1.672, 1.66],
+ [0.356, 0.254, 0.238],
+ [0.134, 0.135, 0.128],
+ [0.229, 0.105, 0.116],
+ [0.54, 0.431, 0.439],
+ [0.265, 0.091, 0.081],
+ [0.138, 0.075, 0.087],
+ [0.085, 0.078, 0.083]
]
}
diff --git a/clickhouse-datalake/results/c6a.large.json b/clickhouse-datalake/results/c6a.large.json
index 1e905fbe3..2b31996fa 100644
--- a/clickhouse-datalake/results/c6a.large.json
+++ b/clickhouse-datalake/results/c6a.large.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.large",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.103, 0.048, 0.061],
- [6.214, 0.148, 0.14],
- [14.948, 0.387, 0.379],
- [18.275, 0.285, 0.277],
- [2.237, 2.189, 2.147],
- [4.076, null, null],
- [7.385, 0.152, 0.151],
- [0.149, 0.146, 0.156],
- [5.943, 2.99, 2.966],
- [3.57, 3.545, 3.595],
- [2.071, 0.848, 0.839],
- [2.113, 0.987, 0.987],
- [null, null, null],
- [8.619, 8.342, 8.068],
- [4.454, 3.818, 3.804],
- [2.485, 2.412, 2.498],
- [null, null, null],
- [null, null, null],
- [null, null, null],
- [0.244, 0.257, 0.237],
- [28.524, 22.432, 21.198],
- [34.445, 33.284, 34.553],
- [73.82, 73.97, 73.732],
- [154.618, 150.562, 150.072],
- [13.827, 2.626, 2.128],
- [1.258, 1.273, 1.272],
- [2.096, 2.06, 2.098],
- [40.419, 32.585, 31.118],
- [null, null, null],
- [5.899, 0.239, 0.241],
- [21.651, 8.533, 3.513],
- [22.2, 17.974, 15.183],
- [null, null, null],
- [null, null, null],
- [null, null, null],
- [9.852, 1.62, 1.659],
- [1.276, 0.266, 0.272],
- [0.381, 0.189, 0.19],
- [0.31, 0.123, 0.117],
- [1.504, 0.469, 0.467],
- [0.598, 0.079, 0.093],
- [0.151, 0.102, 0.092],
- [0.086, 0.08, 0.085]
+ [0.105, 0.073, 0.057],
+ [5.133, 0.146, 0.147],
+ [7.142, 0.369, 0.367],
+ [14.572, 0.27, 0.262],
+ [2.224, 2.248, 2.147],
+ [3.89, null, null],
+ [6.617, 0.147, 0.156],
+ [0.162, 0.151, 0.148],
+ [6.084, 3.008, 2.923],
+ [3.657, 3.626, 3.623],
+ [1.798, 0.642, 0.645],
+ [1.972, 0.786, 0.792],
+ [null, null, null],
+ [8.211, 7.831, 7.895],
+ [4.087, 3.6, 3.613],
+ [2.42, 2.39, 2.405],
+ [null, null, null],
+ [null, null, null],
+ [285.344, null, null],
+ [0.252, 0.247, 0.239],
+ [28.433, 28.398, 28.572],
+ [34.271, 34.525, 34.424],
+ [71.824, 71.936, 71.97],
+ [153.764, 154.798, 154.562],
+ [9.522, 1.688, 1.706],
+ [1.02, 1.028, 1.013],
+ [1.684, 1.687, 1.673],
+ [35.394, 34.865, 34.755],
+ [null, null, null],
+ [0.707, 0.245, 0.248],
+ [20.186, 2.416, 2.457],
+ [28.876, 24.093, 23.786],
+ [null, null, null],
+ [null, null, null],
+ [null, null, null],
+ [9.825, 1.625, 1.632],
+ [1.06, 0.26, 0.258],
+ [0.474, 0.157, 0.161],
+ [0.308, 0.124, 0.124],
+ [1.045, 0.451, 0.432],
+ [0.494, 0.098, 0.102],
+ [0.235, 0.091, 0.089],
+ [0.123, 0.084, 0.083]
]
}
diff --git a/clickhouse-datalake/results/c6a.metal.json b/clickhouse-datalake/results/c6a.metal.json
index b688b75d2..57c741612 100644
--- a/clickhouse-datalake/results/c6a.metal.json
+++ b/clickhouse-datalake/results/c6a.metal.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.118, 0.061, 0.058],
- [5.27, 0.11, 0.117],
- [7.13, 0.307, 0.318],
- [6.27, 0.25, 0.255],
- [1.955, 1.983, 1.953],
- [4.208, 2.734, 2.655],
- [5.452, 0.121, 0.113],
- [0.126, 0.131, 0.134],
- [5.783, 2.552, 2.565],
- [2.985, 2.948, 3.02],
- [1.462, 0.288, 0.276],
- [1.535, 0.357, 0.341],
- [2.564, 2.46, 2.505],
- [3.667, 4.57, 3.799],
- [3.175, 2.548, 2.553],
- [2.367, 2.513, 2.344],
- [8.538, 8.47, 8.561],
- [6.189, 6.077, 6.14],
- [18.991, 15.826, 15.885],
- [0.234, 0.249, 0.232],
- [28.273, 1.756, 1.812],
- [1.733, 1.399, 1.491],
- [33.352, 2.551, 2.631],
- [94.606, 6.449, 6.377],
- [0.502, 0.474, 0.482],
- [0.52, 0.538, 0.533],
- [0.483, 0.485, 0.476],
- [1.485, 1.483, 1.504],
- [45.973, 43.63, 43.675],
- [0.162, 0.14, 0.157],
- [1.44, 1.329, 1.377],
- [2.538, 2.624, 2.477],
- [22.612, 20.863, 20.886],
- [13.181, 11.897, 13.419],
- [12.118, 12.026, 12.306],
- [1.606, 1.509, 1.355],
- [0.233, 0.242, 0.223],
- [0.149, 0.139, 0.143],
- [0.128, 0.124, 0.138],
- [0.404, 0.415, 0.41],
- [0.106, 0.103, 0.102],
- [0.082, 0.084, 0.116],
- [0.074, 0.092, 0.097]
+ [0.121, 0.058, 0.056],
+ [5.259, 0.137, 0.139],
+ [8.963, 0.362, 0.36],
+ [15.343, 0.26, 0.265],
+ [2.051, 2.037, 2.064],
+ [4.328, 2.844, 2.879],
+ [5.572, 0.146, 0.136],
+ [0.137, 0.153, 0.133],
+ [5.915, 2.721, 2.678],
+ [3.177, 3.146, 3.173],
+ [1.599, 0.316, 0.279],
+ [1.508, 0.381, 0.379],
+ [2.677, 2.66, 2.692],
+ [3.973, 4.004, 3.963],
+ [3.277, 2.891, 2.883],
+ [2.49, 2.733, 2.402],
+ [9.664, 9.591, 9.656],
+ [7.024, 7.039, 7.167],
+ [21.803, 19.413, 19.16],
+ [0.239, 0.248, 0.225],
+ [29.219, 1.594, 1.56],
+ [1.723, 1.437, 1.459],
+ [33.829, 2.505, 2.499],
+ [94.425, 6.617, 6.722],
+ [0.459, 0.493, 0.47],
+ [0.54, 0.549, 0.519],
+ [0.5, 0.49, 0.507],
+ [1.718, 1.722, 1.667],
+ [44.083, 44.163, 43.963],
+ [0.163, 0.181, 0.17],
+ [1.57, 1.545, 1.506],
+ [2.882, 2.829, 2.862],
+ [29.425, 29.348, 29.14],
+ [14.424, 14.407, 14.561],
+ [14.725, 14.694, 14.416],
+ [1.529, 1.591, 1.762],
+ [0.228, 0.219, 0.214],
+ [0.135, 0.128, 0.125],
+ [0.114, 0.111, 0.118],
+ [0.398, 0.403, 0.397],
+ [0.077, 0.086, 0.095],
+ [0.09, 0.086, 0.079],
+ [0.065, 0.073, 0.081]
]
}
diff --git a/clickhouse-datalake/results/c6a.xlarge.json b/clickhouse-datalake/results/c6a.xlarge.json
index 28b51c5d8..8c598abec 100644
--- a/clickhouse-datalake/results/c6a.xlarge.json
+++ b/clickhouse-datalake/results/c6a.xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (data lake, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.109, 0.058, 0.055],
- [8.552, 0.101, 0.1],
- [15.077, 0.247, 0.246],
- [18.543, 0.189, 0.183],
- [2.019, 2.05, 2.019],
- [4.713, null, null],
- [7.178, 0.11, 0.106],
- [0.115, 0.111, 0.113],
- [5.867, 2.655, 2.703],
- [3.149, 3.157, 3.053],
- [1.655, 0.46, 0.445],
- [1.648, 0.507, 0.521],
+ [0.109, 0.061, 0.055],
+ [5.826, 0.11, 0.104],
+ [13.182, 0.239, 0.241],
+ [15.283, 0.185, 0.183],
+ [2.118, 2.11, 2.111],
+ [3.426, null, null],
+ [6.74, 0.102, 0.111],
+ [0.111, 0.118, 0.112],
+ [5.823, 2.73, 2.811],
+ [3.29, 3.306, 3.319],
+ [1.597, 0.376, 0.376],
+ [1.629, 0.46, 0.445],
[null, null, null],
- [4.101, 4.136, 4.115],
- [3.128, 3.01, 3.018],
- [2.131, 2.153, 2.182],
- [15.393, 15.39, 15.443],
- [9.877, 9.823, 9.786],
- [30.792, 29.455, 30.194],
- [0.172, 0.173, 0.158],
- [28.203, 26.965, 26.44],
- [33.531, 33.466, 33.673],
- [66.589, 66.835, 67.463],
- [149.967, 151.105, 150.132],
- [13.091, 1.016, 1.015],
- [0.66, 0.665, 0.668],
- [1.019, 1.006, 1.017],
- [32.882, 31.263, 31.329],
- [60.005, 58.002, 57.461],
- [5.814, 0.159, 0.158],
- [21.533, 1.906, 1.888],
- [15.989, 2.924, 2.962],
- [37.408, 37.766, 38.485],
+ [4.277, 4.239, 4.254],
+ [3.247, 3.211, 3.238],
+ [2.249, 2.248, 2.253],
+ [16.639, 16.53, 16.521],
+ [10.304, 10.282, 10.288],
+ [32.234, 30.975, 31.024],
+ [0.175, 0.172, 0.167],
+ [28.393, 28.249, 28.248],
+ [34.334, 34.39, 34.41],
+ [67.949, 67.45, 67.701],
+ [150.055, 150.246, 150.95],
+ [15.705, 0.919, 0.92],
+ [0.608, 0.589, 0.582],
+ [0.914, 0.909, 0.904],
+ [33.003, 32.517, 32.557],
+ [59.867, 59.534, 60.799],
+ [6.365, 0.162, 0.157],
+ [23.892, 1.702, 1.713],
+ [14.471, 5.773, 8.495],
+ [43.759, 43.38, 42.055],
[null, null, null],
- [null, 31.789, null],
- [6.056, 1.517, 1.486],
- [0.605, 0.233, 0.238],
- [0.351, 0.118, 0.132],
- [0.178, 0.105, 0.106],
- [0.802, 0.408, 0.409],
- [0.308, 0.091, 0.082],
- [0.142, 0.083, 0.085],
- [0.081, 0.075, 0.071]
+ [null, null, null],
+ [12.243, 1.527, 1.521],
+ [0.899, 0.234, 0.231],
+ [0.355, 0.134, 0.133],
+ [0.308, 0.112, 0.108],
+ [0.935, 0.418, 0.388],
+ [0.523, 0.087, 0.093],
+ [0.138, 0.087, 0.086],
+ [0.084, 0.078, 0.072]
]
}
diff --git a/clickhouse-datalake/results/c7a.metal-48xl.json b/clickhouse-datalake/results/c7a.metal-48xl.json
index c38cbd77a..b579869cb 100644
--- a/clickhouse-datalake/results/c7a.metal-48xl.json
+++ b/clickhouse-datalake/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, single)",
- "date": "2025-08-30",
+ "system": "ClickHouse (data lake, single)",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.229, 0.055, 0.055],
- [19.796, 0.103, 0.107],
- [23.904, 0.298, 0.292],
- [22.104, 0.222, 0.221],
- [1.909, 1.919, 1.902],
- [7.624, 2.921, 2.953],
- [14.149, 0.115, 0.098],
- [0.112, 0.101, 0.119],
- [12.312, 2.456, 2.495],
- [3.653, 2.95, 2.926],
- [3.193, 0.29, 0.29],
- [1.988, 0.356, 0.361],
- [2.402, 2.4, 2.375],
- [3.542, 3.492, 3.558],
- [3.818, 2.392, 2.316],
- [2.215, 2.239, 2.2],
- [7.946, 7.925, 9.398],
- [5.872, 5.98, 5.912],
- [34.114, 16.181, 15.936],
- [0.206, 0.199, 0.218],
- [70.644, 1.691, 1.63],
- [2.058, 1.301, 1.316],
- [71.261, 2.223, 2.201],
- [242.977, 5.917, 5.95],
- [0.469, 0.466, 0.467],
- [0.481, 0.465, 0.467],
- [0.472, 0.492, 0.479],
- [1.335, 1.42, 1.289],
- [36.207, 35.356, 36.456],
- [0.152, 0.142, 0.149],
- [1.457, 1.36, 1.366],
- [2.777, 2.671, 2.665],
- [18.51, 18.541, 18.465],
- [12.151, 12.01, 15.861],
- [12.248, 12.329, 12.325],
- [1.427, 1.536, 1.531],
- [0.217, 0.216, 0.221],
- [0.145, 0.155, 0.142],
- [0.121, 0.126, 0.115],
- [0.453, 0.444, 0.392],
- [0.092, 0.105, 0.103],
- [0.11, 0.096, 0.094],
- [0.091, 0.085, 0.092]
+ [0.127, 0.062, 0.055],
+ [5.422, 0.114, 0.12],
+ [7.162, 0.335, 0.311],
+ [6.472, 0.239, 0.235],
+ [2.037, 2.015, 2.034],
+ [4.47, 3.074, 3.022],
+ [5.646, 0.11, 0.109],
+ [0.131, 0.117, 0.136],
+ [6.257, 2.658, 2.67],
+ [3.096, 3.147, 3.16],
+ [1.5, 0.34, 0.315],
+ [1.52, 0.355, 0.343],
+ [2.576, 2.457, 2.6],
+ [3.91, 3.886, 3.847],
+ [3.546, 2.74, 2.704],
+ [2.316, 2.342, 2.307],
+ [9.432, 9.267, 9.331],
+ [6.849, 7.058, 6.952],
+ [24.742, 19.258, 19.255],
+ [0.222, 0.202, 0.222],
+ [28.652, 1.457, 1.449],
+ [1.591, 1.333, 1.351],
+ [33.571, 2.425, 2.44],
+ [94.077, 6.382, 6.446],
+ [0.505, 0.497, 0.511],
+ [0.486, 0.462, 0.486],
+ [0.503, 0.498, 0.493],
+ [1.64, 1.657, 1.682],
+ [37.317, 37.091, 37.361],
+ [0.17, 0.165, 0.163],
+ [1.754, 1.843, 1.826],
+ [3.336, 2.904, 3.062],
+ [25.455, 25.254, 25.341],
+ [14.715, 14.537, 14.614],
+ [14.582, 14.346, 14.295],
+ [1.522, 1.58, 1.568],
+ [0.212, 0.22, 0.214],
+ [0.135, 0.134, 0.131],
+ [0.12, 0.122, 0.118],
+ [0.36, 0.427, 0.455],
+ [0.103, 0.095, 0.074],
+ [0.087, 0.085, 0.09],
+ [0.074, 0.076, 0.079]
]
}
+
diff --git a/clickhouse-datalake/results/c8g.4xlarge.json b/clickhouse-datalake/results/c8g.4xlarge.json
index 52cc5b948..926bab2b2 100644
--- a/clickhouse-datalake/results/c8g.4xlarge.json
+++ b/clickhouse-datalake/results/c8g.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, single)",
- "date": "2025-08-28",
+ "system": "ClickHouse (data lake, single)",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.26, 0.051, 0.054],
- [22.424, 0.143, 0.104],
- [24.518, 0.167, 0.167],
- [24.628, 0.142, 0.143],
- [1.528, 1.529, 1.561],
- [6.779, 2.682, 2.667],
- [8.595, 0.09, 0.091],
- [0.088, 0.095, 0.092],
- [5.811, 2.034, 2.045],
- [2.529, 2.486, 2.506],
- [1.503, 0.187, 0.204],
- [1.417, 0.244, 0.265],
- [2.209, 2.256, 2.225],
- [2.975, 2.991, 2.999],
- [2.392, 2.206, 2.22],
- [1.622, 1.627, 1.623],
- [7.921, 7.886, 7.884],
- [5.755, 5.695, 5.745],
- [24.907, 15.223, 15.171],
- [0.13, 0.126, 0.129],
- [36.76, 1.724, 1.711],
- [1.424, 1.166, 1.161],
- [38.178, 2.062, 2.055],
- [133.047, 66.375, 3.421],
- [0.3, 0.304, 0.296],
- [0.369, 0.364, 0.437],
- [0.287, 0.295, 0.3],
- [0.994, 0.998, 0.974],
- [38.254, 38.285, 38.282],
- [0.099, 0.1, 0.121],
- [0.953, 0.952, 0.965],
- [1.855, 1.847, 1.83],
- [17.173, 17.367, 17.351],
- [11.47, 11.234, 11.408],
- [11.403, 11.448, 11.792],
- [1.078, 1.091, 1.076],
- [0.177, 0.182, 0.18],
- [0.099, 0.105, 0.1],
- [0.093, 0.091, 0.092],
- [0.315, 0.318, 0.321],
- [0.096, 0.073, 0.075],
- [0.072, 0.069, 0.065],
- [0.066, 0.063, 0.05]
+ [0.12, 0.055, 0.054],
+ [5.041, 0.102, 0.108],
+ [7.257, 0.17, 0.16],
+ [13.206, 0.141, 0.135],
+ [1.597, 1.589, 1.592],
+ [5.123, 2.763, 2.777],
+ [5.599, 0.094, 0.095],
+ [0.099, 0.088, 0.084],
+ [5.806, 2.164, 2.167],
+ [2.677, 2.708, 2.673],
+ [1.389, 0.202, 0.201],
+ [1.38, 0.269, 0.271],
+ [2.239, 2.276, 2.283],
+ [3.241, 3.22, 3.238],
+ [2.49, 2.353, 2.42],
+ [1.663, 1.675, 1.648],
+ [8.877, 8.917, 8.886],
+ [6.425, 6.475, 6.466],
+ [20.41, 17.5, 17.624],
+ [0.12, 0.135, 0.111],
+ [44.243, 1.691, 1.673],
+ [1.49, 1.118, 1.131],
+ [43.486, 2.001, 2.027],
+ [120.322, 126.286, 122.124],
+ [1.041, 0.295, 0.299],
+ [0.368, 0.374, 0.388],
+ [0.305, 0.297, 0.306],
+ [5.429, 0.911, 0.891],
+ [41.508, 39.152, 39.166],
+ [0.106, 0.111, 0.098],
+ [8.221, 1.17, 1.168],
+ [9.573, 2.249, 2.259],
+ [20.786, 20.716, 20.553],
+ [12.237, 12.029, 12.054],
+ [12.138, 12.027, 12.052],
+ [1.116, 1.132, 1.119],
+ [0.231, 0.19, 0.185],
+ [0.09, 0.11, 0.103],
+ [0.143, 0.094, 0.094],
+ [0.403, 0.315, 0.318],
+ [0.184, 0.074, 0.075],
+ [0.093, 0.072, 0.067],
+ [0.067, 0.07, 0.068]
]
}
+
diff --git a/clickhouse-datalake/results/c8g.metal-48xl.json b/clickhouse-datalake/results/c8g.metal-48xl.json
index 83ebe8715..26f33d3bd 100644
--- a/clickhouse-datalake/results/c8g.metal-48xl.json
+++ b/clickhouse-datalake/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (data lake, single)",
- "date": "2025-08-28",
+ "system": "ClickHouse (data lake, single)",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.111, 0.056, 0.057],
- [16.916, 0.113, 0.114],
- [24.388, 0.232, 0.232],
- [24.602, 0.187, 0.186],
- [1.531, 1.531, 1.535],
- [6.65, 2.632, 2.632],
- [8.444, 0.101, 0.104],
- [0.109, 0.104, 0.117],
- [5.732, 2.014, 2],
- [3.336, 2.559, 2.521],
- [1.485, 0.256, 0.242],
- [1.425, 0.338, 0.317],
- [2.224, 2.235, 2.234],
- [3.038, 3.048, 3.049],
- [3.185, 2.302, 2.319],
- [1.66, 1.669, 1.668],
- [7.82, 7.789, 7.886],
- [5.79, 5.757, 5.752],
- [22.7, 14.776, 14.504],
- [0.184, 0.173, 0.158],
- [38.366, 2.101, 2.013],
- [1.279, 1.064, 1.044],
- [35.558, 1.788, 1.819],
- [119.694, 4.623, 4.571],
- [0.361, 0.375, 0.37],
- [0.459, 0.459, 0.47],
- [0.368, 0.367, 0.369],
- [1.042, 1.08, 1.067],
- [39.286, 39.633, 40.464],
- [0.168, 0.167, 0.165],
- [1.282, 1.243, 1.229],
- [2.337, 2.226, 2.225],
- [16.148, 16.293, 16.205],
- [10.741, 10.629, 10.623],
- [10.592, 10.439, 10.724],
- [1.107, 1.1, 1.1],
- [0.184, 0.2, 0.197],
- [0.124, 0.126, 0.123],
- [0.109, 0.11, 0.112],
- [0.328, 0.338, 0.332],
- [0.086, 0.089, 0.088],
- [0.087, 0.08, 0.086],
- [0.079, 0.081, 0.081]
+ [0.115, 0.049, 0.054],
+ [5.054, 0.126, 0.141],
+ [7.262, 0.242, 0.26],
+ [6.261, 0.187, 0.189],
+ [1.572, 1.569, 1.562],
+ [4.257, 2.611, 2.599],
+ [5.471, 0.112, 0.123],
+ [0.119, 0.128, 0.127],
+ [5.68, 2.081, 2.017],
+ [2.54, 2.554, 2.543],
+ [1.435, 0.286, 0.277],
+ [1.456, 0.348, 0.357],
+ [2.095, 2.1, 2.096],
+ [2.941, 2.906, 2.925],
+ [3.146, 2.272, 2.252],
+ [1.661, 1.665, 1.677],
+ [7.922, 7.949, 7.989],
+ [5.882, 5.875, 5.877],
+ [22.653, 14.945, 14.743],
+ [0.166, 0.185, 0.176],
+ [49.476, 2.017, 2.008],
+ [1.334, 1.092, 1.044],
+ [39.82, 1.805, 1.878],
+ [92.779, 4.75, 4.625],
+ [0.368, 0.365, 0.362],
+ [0.445, 0.439, 0.443],
+ [0.359, 0.354, 0.35],
+ [1.238, 1.238, 1.223],
+ [39.871, 39.84, 39.864],
+ [0.173, 0.185, 0.178],
+ [1.302, 1.28, 1.254],
+ [2.343, 2.269, 2.216],
+ [16.75, 16.879, 16.863],
+ [10.51, 10.301, 10.409],
+ [10.698, 10.308, 10.186],
+ [1.101, 1.093, 1.109],
+ [0.175, 0.169, 0.182],
+ [0.112, 0.101, 0.105],
+ [0.119, 0.11, 0.113],
+ [0.312, 0.318, 0.31],
+ [0.08, 0.081, 0.078],
+ [0.074, 0.071, 0.064],
+ [0.071, 0.067, 0.07]
]
}
+
diff --git a/clickhouse-old/template.json b/clickhouse-old/template.json
deleted file mode 100644
index 52fe41270..000000000
--- a/clickhouse-old/template.json
+++ /dev/null
@@ -1,10 +0,0 @@
-{
- "system": "ClickHouse (25.7)",
- "proprietary": "no",
- "tuned": "no",
- "tags": [
- "C++",
- "column-oriented",
- "ClickHouse derivative"
- ]
-}
diff --git a/clickhouse-parquet-partitioned/results/c6a.2xlarge.json b/clickhouse-parquet-partitioned/results/c6a.2xlarge.json
index 129147c1e..41896f433 100644
--- a/clickhouse-parquet-partitioned/results/c6a.2xlarge.json
+++ b/clickhouse-parquet-partitioned/results/c6a.2xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.027, 0.012, 0.011],
- [0.136, 0.04, 0.039],
- [0.224, 0.082, 0.081],
- [0.589, 0.087, 0.089],
- [1.012, 0.594, 0.594],
- [1.221, 0.904, 0.89],
- [0.139, 0.042, 0.042],
- [0.134, 0.04, 0.041],
- [1.049, 0.696, 0.696],
- [1.722, 0.867, 0.84],
- [0.84, 0.242, 0.24],
- [0.902, 0.266, 0.268],
- [1.367, 0.985, 0.928],
- [3.047, 1.413, 1.448],
- [1.472, 1.085, 1.088],
- [0.851, 0.713, 0.71],
- [3.807, 2.814, 2.836],
- [2.807, 1.798, 1.823],
- [7.253, 5.189, 5.199],
- [0.288, 0.078, 0.077],
- [10.625, 1.237, 1.242],
- [12.226, 1.451, 1.454],
- [23.365, 2.726, 2.706],
- [57.811, 4.915, 29.77],
- [3.063, 0.504, 0.495],
- [0.958, 0.326, 0.329],
- [2.727, 0.504, 0.499],
- [9.623, 1.445, 1.452],
- [10.808, 10.614, 10.535],
- [0.21, 0.07, 0.071],
- [2.684, 0.947, 0.95],
- [6.494, 1.47, 1.331],
- [11.971, 10.937, 11.299],
- [10.834, 4.32, 4.451],
- [10.773, 4.294, 4.343],
- [0.52, 0.493, 0.509],
- [0.257, 0.115, 0.118],
- [0.185, 0.065, 0.073],
- [0.193, 0.046, 0.048],
- [0.366, 0.22, 0.197],
- [0.15, 0.03, 0.031],
- [0.126, 0.027, 0.026],
- [0.121, 0.023, 0.023]
+ [0.036, 0.012, 0.012],
+ [0.188, 0.039, 0.039],
+ [0.307, 0.082, 0.083],
+ [0.51, 0.093, 0.093],
+ [0.826, 0.611, 0.604],
+ [1.059, 0.882, 0.885],
+ [0.164, 0.045, 0.042],
+ [0.178, 0.04, 0.041],
+ [0.98, 0.754, 0.745],
+ [1.621, 0.876, 0.87],
+ [0.764, 0.212, 0.21],
+ [0.816, 0.237, 0.241],
+ [1.23, 0.909, 0.918],
+ [2.84, 1.388, 1.359],
+ [1.316, 1.056, 1.06],
+ [1.04, 0.753, 0.75],
+ [3.665, 2.933, 2.969],
+ [2.57, 1.892, 1.897],
+ [7.142, 5.433, 5.453],
+ [0.484, 0.086, 0.089],
+ [10.216, 1.212, 1.209],
+ [12.065, 1.484, 1.466],
+ [23.088, 2.863, 2.791],
+ [57.028, 7.87, 13.206],
+ [3.012, 0.485, 0.478],
+ [0.951, 0.304, 0.31],
+ [3.007, 0.49, 0.487],
+ [10.485, 1.702, 1.677],
+ [10.954, 10.552, 10.591],
+ [0.359, 0.074, 0.072],
+ [2.954, 0.921, 0.925],
+ [7.007, 1.353, 1.46],
+ [13.261, 12.609, 12.892],
+ [11.708, 8.647, 8.714],
+ [11.007, 4.666, 8.416],
+ [0.648, 0.486, 0.481],
+ [0.276, 0.115, 0.135],
+ [0.183, 0.067, 0.073],
+ [0.218, 0.045, 0.046],
+ [0.397, 0.201, 0.194],
+ [0.158, 0.032, 0.032],
+ [0.125, 0.026, 0.027],
+ [0.126, 0.024, 0.024]
]
}
diff --git a/clickhouse-parquet-partitioned/results/c6a.4xlarge.json b/clickhouse-parquet-partitioned/results/c6a.4xlarge.json
index d6bb2b7c1..e29f10e5d 100644
--- a/clickhouse-parquet-partitioned/results/c6a.4xlarge.json
+++ b/clickhouse-parquet-partitioned/results/c6a.4xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.021, 0.015, 0.012],
- [0.119, 0.033, 0.035],
- [0.153, 0.059, 0.06],
- [0.648, 0.086, 0.087],
- [1.136, 0.403, 0.412],
- [1.163, 0.534, 0.561],
- [0.104, 0.031, 0.036],
- [0.114, 0.033, 0.035],
- [1.011, 0.503, 0.504],
- [1.67, 0.577, 0.607],
- [0.854, 0.211, 0.209],
- [1.07, 0.212, 0.201],
- [1.428, 0.672, 0.659],
- [2.784, 0.973, 0.983],
- [1.379, 0.773, 0.76],
- [0.847, 0.494, 0.486],
- [3.341, 1.845, 1.855],
- [2.644, 1.205, 1.375],
- [6.242, 3.799, 3.786],
- [0.288, 0.075, 0.074],
- [10.557, 1.118, 1.123],
- [11.957, 1.355, 1.378],
- [22.963, 2.417, 2.406],
- [56.707, 2.824, 2.828],
- [3.022, 0.355, 0.352],
- [0.841, 0.248, 0.255],
- [2.734, 0.345, 0.349],
- [9.675, 1.554, 1.54],
- [8.662, 5.644, 5.657],
- [0.145, 0.054, 0.054],
- [2.63, 0.572, 0.582],
- [6.411, 0.971, 0.967],
- [7.07, 4.487, 4.502],
- [10.529, 3.07, 3.036],
- [10.56, 3.107, 3.037],
- [0.401, 0.334, 0.333],
- [0.242, 0.114, 0.115],
- [0.16, 0.07, 0.067],
- [0.183, 0.048, 0.046],
- [0.318, 0.169, 0.173],
- [0.133, 0.028, 0.028],
- [0.117, 0.03, 0.024],
- [0.116, 0.022, 0.023]
+ [0.017, 0.019, 0.02],
+ [0.104, 0.035, 0.037],
+ [0.136, 0.061, 0.059],
+ [0.475, 0.083, 0.094],
+ [0.607, 0.407, 0.41],
+ [0.944, 0.514, 0.5],
+ [0.106, 0.042, 0.04],
+ [0.112, 0.038, 0.044],
+ [0.855, 0.516, 0.503],
+ [1.513, 0.591, 0.574],
+ [0.695, 0.193, 0.188],
+ [0.768, 0.188, 0.193],
+ [1.056, 0.642, 0.657],
+ [2.568, 0.977, 0.988],
+ [1.149, 0.74, 0.727],
+ [0.679, 0.489, 0.492],
+ [3.074, 1.788, 1.808],
+ [2.345, 1.127, 1.116],
+ [5.915, 3.757, 3.793],
+ [0.193, 0.08, 0.082],
+ [9.76, 1.102, 1.111],
+ [11.556, 1.331, 1.321],
+ [22.267, 2.386, 2.407],
+ [55.1, 2.779, 2.781],
+ [2.838, 0.334, 0.346],
+ [0.86, 0.246, 0.247],
+ [2.818, 0.338, 0.349],
+ [9.972, 1.545, 1.529],
+ [8.614, 5.388, 5.435],
+ [0.144, 0.061, 0.059],
+ [2.716, 0.552, 0.563],
+ [6.557, 0.919, 0.927],
+ [7.114, 4.459, 4.469],
+ [10.834, 3.138, 3.095],
+ [10.833, 3.116, 3.077],
+ [0.397, 0.336, 0.336],
+ [0.235, 0.105, 0.109],
+ [0.143, 0.067, 0.065],
+ [0.178, 0.049, 0.043],
+ [0.297, 0.181, 0.174],
+ [0.115, 0.032, 0.031],
+ [0.099, 0.039, 0.022],
+ [0.095, 0.023, 0.025]
]
}
diff --git a/clickhouse-parquet-partitioned/results/c6a.large.json b/clickhouse-parquet-partitioned/results/c6a.large.json
index 7561acb68..3c26eca84 100644
--- a/clickhouse-parquet-partitioned/results/c6a.large.json
+++ b/clickhouse-parquet-partitioned/results/c6a.large.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.large",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.137, 0.03, 0.03],
- [0.333, 0.112, 0.11],
- [0.609, 0.269, 0.27],
- [0.787, 0.232, 0.239],
- [2.11, 1.751, 1.749],
- [3.5, 3.121, 3.146],
- [0.35, 0.12, 0.12],
- [0.376, 0.118, 0.117],
- [2.574, 2.227, 2.225],
- [3.069, 2.728, 2.716],
- [1.331, 0.781, 0.778],
- [1.468, 0.907, 0.908],
- [3.496, 3.059, 3.026],
- [7.681, 6.86, 6.956],
- [4.152, 3.695, 3.732],
- [2.329, 1.94, 1.949],
- [12.686, 12.23, 12.285],
- [9.594, 9.343, 9.29],
- [25.301, 24.425, 25.997],
- [0.701, 0.215, 0.217],
- [9.541, 4.977, 5.062],
- [11.23, 6.101, 8.074],
- [21.871, 21.829, 21.921],
- [53.828, 53.754, 53.773],
- [2.841, 1.98, 1.811],
- [1.783, 1.204, 1.187],
- [2.916, 1.779, 1.78],
- [10, 4.975, 4.993],
- [42.436, 41.672, 41.853],
- [0.486, 0.207, 0.209],
- [4.152, 3.396, 3.4],
- [7.005, 4.329, 4.349],
- [30.329, 29.764, 31.298],
- [30.081, 30.065, 30.439],
- [29.631, 30.584, 29.971],
- [1.573, 1.27, 1.253],
- [0.522, 0.229, 0.222],
- [0.335, 0.125, 0.122],
- [0.372, 0.09, 0.095],
- [0.633, 0.372, 0.403],
- [0.258, 0.063, 0.063],
- [0.252, 0.06, 0.059],
- [0.252, 0.054, 0.054]
+ [0.105, 0.031, 0.031],
+ [0.317, 0.113, 0.115],
+ [0.606, 0.286, 0.287],
+ [0.787, 0.238, 0.237],
+ [2.2, 1.885, 1.884],
+ [3.367, 3.085, 3.099],
+ [0.34, 0.123, 0.122],
+ [0.33, 0.116, 0.116],
+ [2.723, 2.403, 2.436],
+ [3.236, 2.958, 2.985],
+ [1.201, 0.679, 0.683],
+ [1.319, 0.796, 0.788],
+ [3.362, 2.986, 3.001],
+ [7.471, 6.944, 6.983],
+ [4.001, 3.594, 3.596],
+ [2.4, 2.037, 2.003],
+ [12.213, 12.036, 11.922],
+ [9.582, 9.007, 9.42],
+ [24.811, 23.127, 24.145],
+ [0.687, 0.217, 0.215],
+ [9.494, 3.314, 3.275],
+ [11.38, 4.251, 8.073],
+ [21.865, 21.742, 21.733],
+ [53.886, 53.706, 53.725],
+ [2.759, 1.606, 1.606],
+ [1.642, 1.007, 0.997],
+ [2.725, 1.598, 1.602],
+ [9.708, 3.791, 3.825],
+ [41.913, 41.013, 40.957],
+ [0.499, 0.218, 0.218],
+ [3.946, 3.227, 3.204],
+ [7.011, 4.212, 4.192],
+ [30.125, 29.704, 30.505],
+ [27.077, 26.628, 27.052],
+ [27.105, 27.213, 27.573],
+ [1.638, 1.352, 1.34],
+ [0.437, 0.219, 0.216],
+ [0.299, 0.124, 0.12],
+ [0.33, 0.09, 0.092],
+ [0.577, 0.356, 0.353],
+ [0.256, 0.067, 0.065],
+ [0.237, 0.062, 0.063],
+ [0.227, 0.056, 0.059]
]
}
diff --git a/clickhouse-parquet-partitioned/results/c6a.metal.json b/clickhouse-parquet-partitioned/results/c6a.metal.json
index b4f241c7b..c412ae302 100644
--- a/clickhouse-parquet-partitioned/results/c6a.metal.json
+++ b/clickhouse-parquet-partitioned/results/c6a.metal.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.056, 0.047, 0.05],
- [0.111, 0.058, 0.055],
- [0.157, 0.077, 0.075],
- [0.701, 0.094, 0.102],
- [1.052, 0.269, 0.27],
- [1.059, 0.263, 0.261],
- [0.111, 0.069, 0.06],
- [0.121, 0.062, 0.067],
- [1.062, 0.374, 0.386],
- [1.65, 0.395, 0.383],
- [0.841, 0.183, 0.194],
- [0.921, 0.157, 0.183],
- [1.213, 0.278, 0.266],
- [2.464, 0.296, 0.298],
- [1.109, 0.276, 0.285],
- [0.627, 0.202, 0.185],
- [2.559, 0.416, 0.417],
- [2.49, 0.359, 0.346],
- [4.559, 0.838, 0.822],
- [0.299, 0.089, 0.101],
- [10.202, 0.392, 0.378],
- [11.648, 0.441, 0.48],
- [22.308, 0.663, 0.705],
- [54.693, 1.043, 1.065],
- [2.862, 0.156, 0.176],
- [1.098, 0.129, 0.129],
- [3.122, 0.158, 0.164],
- [9.873, 0.509, 0.506],
- [8.527, 1.267, 1.287],
- [0.167, 0.092, 0.093],
- [2.577, 0.214, 0.206],
- [6.261, 0.299, 0.309],
- [5.09, 1.012, 1.035],
- [9.792, 0.722, 0.824],
- [9.789, 0.803, 0.856],
- [0.286, 0.16, 0.166],
- [0.247, 0.139, 0.147],
- [0.186, 0.094, 0.095],
- [0.199, 0.088, 0.087],
- [0.28, 0.189, 0.123],
- [0.127, 0.075, 0.07],
- [0.124, 0.07, 0.063],
- [0.118, 0.056, 0.054]
+ [0.138, 0.044, 0.04],
+ [0.272, 0.076, 0.071],
+ [0.457, 0.072, 0.087],
+ [0.837, 0.104, 0.109],
+ [1.087, 0.269, 0.285],
+ [1.44, 0.268, 0.25],
+ [0.25, 0.063, 0.072],
+ [0.103, 0.071, 0.083],
+ [1.02, 0.394, 0.385],
+ [1.646, 0.397, 0.404],
+ [0.818, 0.195, 0.2],
+ [1.116, 0.174, 0.188],
+ [1.329, 0.288, 0.27],
+ [2.452, 0.323, 0.326],
+ [1.094, 0.286, 0.311],
+ [0.592, 0.204, 0.229],
+ [2.568, 0.449, 0.441],
+ [2.473, 0.377, 0.362],
+ [4.644, 0.868, 0.89],
+ [0.286, 0.1, 0.106],
+ [15.022, 0.388, 0.394],
+ [11.671, 0.452, 0.461],
+ [22.214, 0.718, 0.729],
+ [57.412, 1.075, 1.064],
+ [2.858, 0.166, 0.173],
+ [1.154, 0.165, 0.149],
+ [3.173, 0.184, 0.188],
+ [9.687, 0.544, 0.544],
+ [8.336, 1.148, 1.052],
+ [0.15, 0.091, 0.108],
+ [2.576, 0.238, 0.235],
+ [6.217, 0.331, 0.328],
+ [5.26, 1.07, 1.104],
+ [9.875, 0.956, 0.757],
+ [9.867, 0.888, 0.803],
+ [0.223, 0.167, 0.175],
+ [0.214, 0.146, 0.137],
+ [0.152, 0.099, 0.125],
+ [0.163, 0.099, 0.086],
+ [0.279, 0.217, 0.205],
+ [0.115, 0.07, 0.07],
+ [0.123, 0.071, 0.059],
+ [0.118, 0.057, 0.056]
]
}
diff --git a/clickhouse-parquet-partitioned/results/c6a.xlarge.json b/clickhouse-parquet-partitioned/results/c6a.xlarge.json
index 50a02bd3d..a95657165 100644
--- a/clickhouse-parquet-partitioned/results/c6a.xlarge.json
+++ b/clickhouse-parquet-partitioned/results/c6a.xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.054, 0.017, 0.017],
- [0.198, 0.065, 0.062],
- [0.365, 0.143, 0.144],
- [0.8, 0.131, 0.134],
- [1.589, 0.925, 0.92],
- [1.739, 1.582, 1.586],
- [0.201, 0.065, 0.066],
- [0.206, 0.064, 0.065],
- [1.398, 1.228, 1.23],
- [2.186, 1.483, 1.476],
- [1.031, 0.417, 0.414],
- [1.252, 0.483, 0.482],
- [1.844, 1.641, 1.641],
- [3.928, 2.439, 2.451],
- [2.04, 1.851, 1.847],
- [1.248, 1.034, 1.032],
- [8.58, 6.886, 6.853],
- [5.235, 4.988, 5.131],
- [14.276, 13.796, 13.595],
- [0.404, 0.116, 0.117],
- [9.451, 2.249, 2.232],
- [11.221, 2.723, 2.756],
- [21.642, 5.029, 5.082],
- [53.641, 54.013, 54.047],
- [2.72, 0.895, 0.901],
- [0.921, 0.599, 0.597],
- [2.731, 0.91, 0.909],
- [9.639, 2.276, 2.283],
- [21.004, 20.765, 20.701],
- [0.321, 0.112, 0.115],
- [2.768, 1.816, 1.709],
- [6.68, 2.472, 2.516],
- [18.153, 17.503, 17.569],
- [18.909, 14.178, 14.483],
- [19.284, 14.243, 14.04],
- [0.986, 0.801, 0.794],
- [0.308, 0.151, 0.134],
- [0.225, 0.08, 0.076],
- [0.236, 0.055, 0.06],
- [0.401, 0.231, 0.24],
- [0.178, 0.039, 0.04],
- [0.161, 0.035, 0.035],
- [0.156, 0.032, 0.032]
+ [0.083, 0.017, 0.018],
+ [0.323, 0.062, 0.062],
+ [0.616, 0.145, 0.146],
+ [0.984, 0.134, 0.133],
+ [1.271, 0.93, 0.941],
+ [1.821, 1.533, 1.524],
+ [0.354, 0.069, 0.067],
+ [0.181, 0.065, 0.065],
+ [1.405, 1.276, 1.247],
+ [2.152, 1.527, 1.529],
+ [0.986, 0.343, 0.348],
+ [1.269, 0.411, 0.417],
+ [1.832, 1.556, 1.565],
+ [3.786, 2.339, 2.348],
+ [1.897, 1.749, 1.744],
+ [1.244, 1.03, 1.039],
+ [5.218, 6.497, 6.614],
+ [3.428, 4.944, 4.98],
+ [13.433, 13.07, 13.336],
+ [0.359, 0.12, 0.121],
+ [9.702, 1.734, 1.764],
+ [11.188, 2.148, 2.135],
+ [21.814, 4.158, 4.158],
+ [53.66, 53.827, 53.85],
+ [2.718, 0.825, 0.827],
+ [0.812, 0.525, 0.517],
+ [2.74, 0.827, 0.827],
+ [9.657, 2.043, 2.034],
+ [20.803, 20.508, 20.51],
+ [0.301, 0.119, 0.117],
+ [2.723, 1.601, 1.599],
+ [6.663, 2.494, 2.361],
+ [17.743, 17.143, 16.921],
+ [19.645, 13.871, 14.202],
+ [18.919, 14.405, 14.301],
+ [0.951, 0.817, 0.817],
+ [0.285, 0.135, 0.136],
+ [0.187, 0.079, 0.081],
+ [0.231, 0.059, 0.059],
+ [0.378, 0.225, 0.223],
+ [0.164, 0.041, 0.04],
+ [0.155, 0.035, 0.035],
+ [0.146, 0.033, 0.031]
]
}
diff --git a/clickhouse-parquet-partitioned/results/c7a.metal-48xl.json b/clickhouse-parquet-partitioned/results/c7a.metal-48xl.json
index 523174283..dbf3abcc6 100644
--- a/clickhouse-parquet-partitioned/results/c7a.metal-48xl.json
+++ b/clickhouse-parquet-partitioned/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-30",
+ "system": "ClickHouse (Parquet, partitioned)",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.074, 0.057, 0.041],
- [0.116, 0.083, 0.07],
- [0.668, 0.086, 0.082],
- [1.383, 0.102, 0.1],
- [1.604, 0.434, 0.43],
- [1.518, 0.441, 0.461],
- [0.107, 0.071, 0.079],
- [0.129, 0.078, 0.075],
- [1.442, 0.38, 0.399],
- [1.977, 0.408, 0.412],
- [1.165, 0.232, 0.22],
- [1.431, 0.201, 0.191],
- [1.709, 0.273, 0.277],
- [2.701, 0.288, 0.304],
- [1.268, 0.234, 0.257],
- [0.949, 0.193, 0.183],
- [2.962, 0.346, 0.336],
- [2.533, 0.329, 0.353],
- [4.538, 0.582, 0.574],
- [0.442, 0.085, 0.082],
- [10.658, 0.368, 0.347],
- [11.918, 0.455, 0.458],
- [22.48, 0.657, 0.647],
- [54.079, 0.993, 0.986],
- [2.752, 0.167, 0.173],
- [0.873, 0.141, 0.142],
- [2.748, 0.174, 0.171],
- [9.714, 0.437, 0.449],
- [8.184, 0.638, 0.631],
- [0.188, 0.109, 0.11],
- [2.582, 0.235, 0.223],
- [6.195, 0.277, 0.246],
- [4.845, 0.723, 0.726],
- [9.703, 0.622, 0.611],
- [9.728, 0.61, 0.612],
- [0.241, 0.173, 0.184],
- [0.254, 0.16, 0.158],
- [0.196, 0.123, 0.132],
- [0.188, 0.095, 0.124],
- [0.247, 0.143, 0.146],
- [0.146, 0.074, 0.081],
- [0.144, 0.07, 0.075],
- [0.115, 0.073, 0.073]
+ [0.084, 0.062, 0.056],
+ [0.16, 0.091, 0.086],
+ [0.31, 0.093, 0.096],
+ [0.623, 0.119, 0.123],
+ [1.126, 0.475, 0.448],
+ [1.212, 0.476, 0.473],
+ [0.215, 0.086, 0.098],
+ [0.233, 0.099, 0.089],
+ [1.022, 0.42, 0.399],
+ [1.645, 0.43, 0.431],
+ [1.058, 0.251, 0.242],
+ [0.914, 0.208, 0.216],
+ [1.083, 0.268, 0.283],
+ [2.421, 0.334, 0.299],
+ [1.132, 0.263, 0.235],
+ [0.691, 0.194, 0.213],
+ [2.437, 0.366, 0.385],
+ [2.425, 0.369, 0.372],
+ [4.42, 0.612, 0.623],
+ [0.611, 0.113, 0.103],
+ [9.855, 0.408, 0.39],
+ [11.573, 0.465, 0.476],
+ [22.352, 0.624, 0.638],
+ [54.422, 1.012, 1.013],
+ [2.846, 0.192, 0.181],
+ [0.935, 0.158, 0.17],
+ [2.842, 0.186, 0.192],
+ [10.069, 0.513, 0.457],
+ [8.344, 0.662, 0.648],
+ [0.493, 0.117, 0.119],
+ [2.661, 0.231, 0.239],
+ [6.356, 0.303, 0.291],
+ [5.005, 0.785, 0.795],
+ [9.979, 0.685, 0.7],
+ [9.979, 0.671, 0.641],
+ [0.636, 0.175, 0.185],
+ [0.298, 0.16, 0.182],
+ [0.249, 0.133, 0.135],
+ [0.335, 0.132, 0.142],
+ [0.406, 0.155, 0.156],
+ [0.193, 0.077, 0.082],
+ [0.153, 0.071, 0.084],
+ [0.199, 0.074, 0.092]
]
}
+
diff --git a/clickhouse-parquet-partitioned/results/c8g.4xlarge.json b/clickhouse-parquet-partitioned/results/c8g.4xlarge.json
index ac00cf43b..a5c7a6529 100644
--- a/clickhouse-parquet-partitioned/results/c8g.4xlarge.json
+++ b/clickhouse-parquet-partitioned/results/c8g.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-28",
+ "system": "ClickHouse (Parquet, partitioned)",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.017, 0.017, 0.021],
- [0.142, 0.025, 0.027],
- [0.194, 0.044, 0.04],
- [0.852, 0.054, 0.055],
- [1.112, 0.19, 0.19],
- [1.126, 0.371, 0.377],
- [0.144, 0.029, 0.031],
- [0.087, 0.025, 0.026],
- [0.879, 0.255, 0.26],
- [1.524, 0.31, 0.318],
- [0.839, 0.124, 0.15],
- [1.076, 0.142, 0.149],
- [1.365, 0.369, 0.36],
- [2.575, 0.511, 0.504],
- [1.163, 0.406, 0.402],
- [0.639, 0.232, 0.234],
- [2.804, 0.843, 0.946],
- [2.574, 0.562, 0.585],
- [5.054, 1.597, 1.603],
- [0.256, 0.048, 0.047],
- [10.937, 0.471, 0.454],
- [11.985, 0.604, 0.584],
- [23.649, 0.966, 0.985],
- [57.395, 1.217, 1.221],
- [2.949, 0.22, 0.205],
- [1.193, 0.145, 0.148],
- [3.248, 0.217, 0.213],
- [10.506, 0.476, 0.492],
- [8.858, 3.07, 3.046],
- [0.133, 0.047, 0.051],
- [2.824, 0.353, 0.339],
- [6.65, 0.454, 0.461],
- [5.597, 1.677, 1.601],
- [10.525, 1.351, 1.339],
- [10.545, 1.304, 1.295],
- [0.247, 0.188, 0.188],
- [0.176, 0.085, 0.09],
- [0.126, 0.06, 0.055],
- [0.158, 0.042, 0.038],
- [0.23, 0.134, 0.129],
- [0.103, 0.029, 0.024],
- [0.094, 0.028, 0.031],
- [0.087, 0.021, 0.022]
+ [0.022, 0.013, 0.014],
+ [0.092, 0.023, 0.034],
+ [0.139, 0.048, 0.041],
+ [1.023, 0.052, 0.055],
+ [1.151, 0.199, 0.186],
+ [1.284, 0.341, 0.355],
+ [0.131, 0.031, 0.024],
+ [0.108, 0.026, 0.027],
+ [0.924, 0.251, 0.276],
+ [1.637, 0.299, 0.307],
+ [0.895, 0.12, 0.129],
+ [1.253, 0.132, 0.137],
+ [1.486, 0.355, 0.334],
+ [2.591, 0.477, 0.483],
+ [1.267, 0.377, 0.398],
+ [0.685, 0.218, 0.212],
+ [2.77, 0.759, 0.879],
+ [2.622, 0.573, 0.53],
+ [5.082, 1.523, 1.518],
+ [0.29, 0.044, 0.05],
+ [10.643, 0.471, 0.481],
+ [12.12, 0.567, 0.563],
+ [22.99, 0.936, 0.941],
+ [56.743, 1.22, 1.199],
+ [3.03, 0.187, 0.186],
+ [1.24, 0.131, 0.131],
+ [3.35, 0.188, 0.193],
+ [9.656, 0.485, 0.486],
+ [8.301, 2.96, 2.954],
+ [0.144, 0.056, 0.055],
+ [2.589, 0.316, 0.308],
+ [6.223, 0.417, 0.42],
+ [5.28, 1.656, 1.613],
+ [9.783, 1.25, 1.223],
+ [9.775, 1.24, 1.262],
+ [0.301, 0.173, 0.179],
+ [0.193, 0.074, 0.076],
+ [0.131, 0.041, 0.042],
+ [0.157, 0.032, 0.032],
+ [0.26, 0.119, 0.118],
+ [0.095, 0.021, 0.021],
+ [0.088, 0.024, 0.018],
+ [0.09, 0.018, 0.018]
]
}
+
diff --git a/clickhouse-parquet-partitioned/results/c8g.metal-48xl.json b/clickhouse-parquet-partitioned/results/c8g.metal-48xl.json
index f100fb792..a498a08e1 100644
--- a/clickhouse-parquet-partitioned/results/c8g.metal-48xl.json
+++ b/clickhouse-parquet-partitioned/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (Parquet, partitioned)",
- "date": "2025-08-28",
+ "system": "ClickHouse (Parquet, partitioned)",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14737666736,
"result": [
- [0.047, 0.042, 0.04],
- [0.104, 0.066, 0.048],
- [0.595, 0.069, 0.059],
- [1.332, 0.06, 0.064],
- [1.441, 0.25, 0.247],
- [1.597, 0.302, 0.291],
- [0.104, 0.055, 0.057],
- [0.103, 0.073, 0.055],
- [1.274, 0.259, 0.268],
- [1.988, 0.279, 0.272],
- [1.121, 0.164, 0.163],
- [1.334, 0.122, 0.133],
- [1.546, 0.223, 0.173],
- [2.692, 0.312, 0.247],
- [1.118, 0.205, 0.186],
- [0.822, 0.131, 0.141],
- [2.916, 0.293, 0.334],
- [2.427, 0.315, 0.297],
- [4.469, 0.496, 0.498],
- [0.344, 0.067, 0.061],
- [10.59, 0.321, 0.338],
- [11.701, 0.452, 0.463],
- [22.38, 0.598, 0.573],
- [54.429, 1.078, 0.966],
- [2.734, 0.138, 0.129],
- [0.85, 0.131, 0.114],
- [2.731, 0.134, 0.131],
- [9.698, 0.446, 0.41],
- [8.038, 0.497, 0.559],
- [0.223, 0.116, 0.115],
- [2.565, 0.175, 0.174],
- [6.188, 0.229, 0.204],
- [4.854, 0.726, 0.784],
- [9.745, 0.489, 0.527],
- [9.716, 0.504, 0.59],
- [0.262, 0.109, 0.105],
- [0.207, 0.101, 0.095],
- [0.172, 0.104, 0.082],
- [0.167, 0.071, 0.076],
- [0.196, 0.105, 0.109],
- [0.118, 0.069, 0.058],
- [0.101, 0.064, 0.056],
- [0.091, 0.063, 0.053]
+ [0.091, 0.054, 0.054],
+ [0.297, 0.077, 0.075],
+ [0.794, 0.072, 0.075],
+ [1.541, 0.086, 0.093],
+ [1.682, 0.371, 0.379],
+ [2.076, 0.354, 0.359],
+ [0.315, 0.078, 0.077],
+ [0.329, 0.081, 0.075],
+ [1.959, 0.3, 0.301],
+ [2.627, 0.339, 0.315],
+ [1.806, 0.184, 0.176],
+ [1.82, 0.148, 0.167],
+ [2.001, 0.214, 0.221],
+ [3.377, 0.243, 0.261],
+ [1.994, 0.207, 0.207],
+ [1.616, 0.181, 0.171],
+ [3.435, 0.348, 0.329],
+ [2.287, 0.324, 0.354],
+ [4.237, 0.517, 0.512],
+ [0.197, 0.069, 0.067],
+ [9.676, 0.334, 0.342],
+ [11.262, 0.436, 0.429],
+ [21.702, 0.603, 0.608],
+ [53.63, 1.038, 0.972],
+ [2.739, 0.148, 0.156],
+ [0.832, 0.145, 0.147],
+ [2.741, 0.155, 0.157],
+ [9.686, 0.423, 0.384],
+ [8.036, 0.519, 0.524],
+ [0.19, 0.124, 0.132],
+ [2.567, 0.197, 0.204],
+ [6.198, 0.267, 0.266],
+ [4.873, 0.735, 0.717],
+ [9.697, 0.543, 0.534],
+ [9.711, 0.572, 0.674],
+ [0.183, 0.133, 0.155],
+ [0.181, 0.119, 0.114],
+ [0.145, 0.089, 0.096],
+ [0.189, 0.084, 0.066],
+ [0.198, 0.103, 0.112],
+ [0.114, 0.07, 0.064],
+ [0.101, 0.065, 0.069],
+ [0.111, 0.067, 0.068]
]
}
+
diff --git a/clickhouse-parquet/results/c6a.2xlarge.json b/clickhouse-parquet/results/c6a.2xlarge.json
index 47db6a141..c3f61acc6 100644
--- a/clickhouse-parquet/results/c6a.2xlarge.json
+++ b/clickhouse-parquet/results/c6a.2xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (Parquet, single)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.038, 0.026, 0.025],
- [0.157, 0.053, 0.052],
- [0.241, 0.095, 0.096],
- [0.359, 0.122, 0.122],
- [0.715, 0.62, 0.615],
- [1.022, 0.931, 0.935],
- [0.156, 0.055, 0.057],
- [0.161, 0.055, 0.056],
- [0.829, 0.725, 0.736],
- [1.226, 0.861, 0.87],
- [0.536, 0.286, 0.289],
- [0.578, 0.31, 0.314],
- [1.106, 0.967, 0.981],
- [2.436, 1.413, 1.434],
- [1.299, 1.105, 1.106],
- [0.858, 0.74, 0.74],
- [3.095, 3.952, 3.852],
- [2.09, 2.813, 2.816],
- [6.325, 8.2, 8.074],
- [0.285, 0.124, 0.117],
- [9.539, 1.349, 1.356],
- [11.221, 2.109, 2.083],
- [21.871, 4.12, 4.115],
- [54.737, 45.161, 28.963],
- [2.535, 0.574, 0.556],
- [0.77, 0.351, 0.359],
- [2.541, 0.556, 0.558],
- [9.683, 1.908, 1.889],
- [11.327, 11.137, 11.118],
- [0.219, 0.092, 0.087],
- [2.451, 0.986, 0.987],
- [6.172, 1.388, 1.372],
- [13.069, 12.455, 11.382],
- [11.031, 8.422, 8.464],
- [11.012, 8.472, 8.377],
- [0.538, 0.436, 0.435],
- [0.286, 0.117, 0.125],
- [0.219, 0.08, 0.085],
- [0.236, 0.067, 0.065],
- [0.288, 0.152, 0.151],
- [0.162, 0.046, 0.045],
- [0.148, 0.043, 0.041],
- [0.143, 0.038, 0.038]
+ [0.036, 0.026, 0.026],
+ [0.119, 0.053, 0.055],
+ [0.231, 0.098, 0.098],
+ [0.359, 0.121, 0.122],
+ [0.698, 0.605, 0.602],
+ [0.975, 0.901, 0.897],
+ [0.138, 0.059, 0.058],
+ [0.151, 0.056, 0.057],
+ [0.802, 0.717, 0.717],
+ [1.243, 0.86, 0.864],
+ [0.54, 0.231, 0.227],
+ [0.566, 0.258, 0.256],
+ [1.012, 0.926, 0.921],
+ [2.452, 1.336, 1.328],
+ [1.211, 1.028, 1.028],
+ [0.811, 0.718, 0.719],
+ [3.072, 3.712, 3.695],
+ [2.119, 2.726, 2.733],
+ [6.334, 7.757, 7.85],
+ [0.267, 0.117, 0.117],
+ [9.854, 1.257, 1.248],
+ [11.566, 1.84, 1.838],
+ [22.58, 3.725, 3.689],
+ [56.382, 51.485, 46.054],
+ [2.598, 0.503, 0.507],
+ [0.766, 0.32, 0.323],
+ [2.614, 0.506, 0.513],
+ [9.967, 1.743, 1.708],
+ [10.819, 11.125, 11.129],
+ [0.209, 0.086, 0.087],
+ [2.496, 0.911, 0.914],
+ [6.327, 1.298, 1.31],
+ [11.782, 10.513, 10.554],
+ [11.131, 7.989, 7.967],
+ [11.123, 8.075, 8.127],
+ [0.529, 0.438, 0.442],
+ [0.269, 0.127, 0.12],
+ [0.208, 0.084, 0.081],
+ [0.229, 0.067, 0.068],
+ [0.286, 0.146, 0.148],
+ [0.157, 0.048, 0.044],
+ [0.142, 0.041, 0.047],
+ [0.137, 0.04, 0.039]
]
}
diff --git a/clickhouse-parquet/results/c8g.4xlarge.json b/clickhouse-parquet/results/c8g.4xlarge.json
index 1054d0294..a02377e67 100644
--- a/clickhouse-parquet/results/c8g.4xlarge.json
+++ b/clickhouse-parquet/results/c8g.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (Parquet, single)",
- "date": "2025-08-28",
+ "system": "ClickHouse (Parquet, single)",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.031, 0.021, 0.021],
- [0.111, 0.041, 0.04],
- [0.158, 0.053, 0.055],
- [0.347, 0.062, 0.064],
- [0.411, 0.21, 0.214],
- [0.781, 0.336, 0.343],
- [0.114, 0.04, 0.041],
- [0.12, 0.044, 0.041],
- [0.649, 0.261, 0.261],
- [1.155, 0.322, 0.313],
- [0.542, 0.183, 0.182],
- [0.58, 0.182, 0.187],
- [0.826, 0.333, 0.333],
- [2.131, 0.473, 0.48],
- [0.899, 0.383, 0.377],
- [0.43, 0.23, 0.239],
- [2.285, 0.853, 0.818],
- [2.034, 0.563, 0.558],
- [4.432, 2.726, 2.651],
- [0.233, 0.061, 0.06],
- [9.561, 0.534, 0.532],
- [11.197, 0.986, 1.003],
- [21.822, 1.795, 1.753],
- [54.601, 1.57, 1.59],
- [2.53, 0.255, 0.254],
- [0.752, 0.158, 0.161],
- [2.526, 0.252, 0.254],
- [9.672, 0.746, 0.756],
- [8.032, 2.878, 2.867],
- [0.155, 0.062, 0.061],
- [2.333, 0.353, 0.356],
- [5.871, 0.496, 0.497],
- [5.008, 1.699, 1.657],
- [9.918, 1.393, 1.381],
- [9.924, 1.396, 1.379],
- [0.292, 0.182, 0.192],
- [0.23, 0.092, 0.097],
- [0.173, 0.066, 0.065],
- [0.192, 0.052, 0.052],
- [0.219, 0.083, 0.089],
- [0.133, 0.037, 0.037],
- [0.121, 0.033, 0.033],
- [0.117, 0.032, 0.031]
+ [0.039, 0.022, 0.022],
+ [0.19, 0.04, 0.041],
+ [0.214, 0.053, 0.054],
+ [0.38, 0.062, 0.063],
+ [0.396, 0.205, 0.203],
+ [0.747, 0.323, 0.322],
+ [0.198, 0.044, 0.045],
+ [0.101, 0.043, 0.041],
+ [0.635, 0.264, 0.293],
+ [1.132, 0.323, 0.322],
+ [0.524, 0.149, 0.145],
+ [0.564, 0.149, 0.15],
+ [0.815, 0.31, 0.305],
+ [2.097, 0.448, 0.446],
+ [0.869, 0.368, 0.358],
+ [0.415, 0.238, 0.237],
+ [2.264, 0.783, 0.787],
+ [2.004, 0.538, 0.537],
+ [4.399, 2.567, 2.6],
+ [0.209, 0.059, 0.059],
+ [9.568, 0.524, 0.527],
+ [11.179, 0.945, 0.949],
+ [22.581, 1.712, 1.71],
+ [54.609, 1.604, 1.601],
+ [2.511, 0.228, 0.223],
+ [0.73, 0.149, 0.149],
+ [2.511, 0.228, 0.229],
+ [9.644, 0.746, 0.745],
+ [8.019, 2.897, 2.903],
+ [0.126, 0.062, 0.059],
+ [2.318, 0.334, 0.334],
+ [5.864, 0.47, 0.473],
+ [4.97, 1.703, 1.697],
+ [9.852, 1.336, 1.329],
+ [9.878, 1.339, 1.338],
+ [0.268, 0.188, 0.192],
+ [0.226, 0.087, 0.09],
+ [0.166, 0.062, 0.059],
+ [0.193, 0.05, 0.05],
+ [0.215, 0.083, 0.084],
+ [0.129, 0.038, 0.038],
+ [0.114, 0.033, 0.032],
+ [0.112, 0.03, 0.03]
]
}
+
diff --git a/clickhouse-parquet/results/c8g.metal-48xl.json b/clickhouse-parquet/results/c8g.metal-48xl.json
index a8b04e768..a30bd78ee 100644
--- a/clickhouse-parquet/results/c8g.metal-48xl.json
+++ b/clickhouse-parquet/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (Parquet, single)",
- "date": "2025-08-28",
+ "system": "ClickHouse (Parquet, single)",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","embedded","stateless","ClickHouse derivative"],
"load_time": 0,
"data_size": 14779976446,
"result": [
- [0.035, 0.024, 0.024],
- [0.114, 0.046, 0.045],
- [0.159, 0.059, 0.054],
- [0.368, 0.066, 0.073],
- [0.538, 0.228, 0.253],
- [0.933, 0.308, 0.251],
- [0.111, 0.044, 0.045],
- [0.126, 0.057, 0.059],
- [0.788, 0.286, 0.269],
- [1.304, 0.283, 0.288],
- [0.585, 0.157, 0.176],
- [0.639, 0.137, 0.141],
- [0.876, 0.171, 0.178],
- [2.127, 0.254, 0.32],
- [0.928, 0.225, 0.204],
- [0.42, 0.159, 0.128],
- [2.165, 0.317, 0.301],
- [2.191, 0.408, 0.325],
- [4.061, 0.496, 0.627],
- [0.278, 0.067, 0.069],
- [9.76, 0.362, 0.383],
- [11.553, 0.48, 0.499],
- [22.402, 0.812, 0.809],
- [55.782, 1.142, 1.076],
- [2.61, 0.156, 0.16],
- [0.817, 0.099, 0.107],
- [2.612, 0.152, 0.156],
- [9.978, 0.485, 0.469],
- [8.254, 0.522, 0.536],
- [0.206, 0.1, 0.1],
- [2.393, 0.172, 0.18],
- [5.956, 0.265, 0.294],
- [4.491, 0.642, 0.686],
- [9.963, 0.622, 0.607],
- [9.907, 0.557, 0.586],
- [0.278, 0.12, 0.111],
- [0.248, 0.109, 0.11],
- [0.178, 0.08, 0.081],
- [0.201, 0.06, 0.061],
- [0.234, 0.097, 0.095],
- [0.14, 0.049, 0.048],
- [0.129, 0.042, 0.043],
- [0.124, 0.042, 0.041]
+ [0.035, 0.025, 0.025],
+ [0.118, 0.077, 0.079],
+ [0.121, 0.058, 0.067],
+ [0.324, 0.063, 0.066],
+ [0.58, 0.338, 0.344],
+ [0.865, 0.364, 0.345],
+ [0.085, 0.057, 0.061],
+ [0.121, 0.076, 0.082],
+ [0.762, 0.298, 0.287],
+ [1.243, 0.307, 0.311],
+ [0.539, 0.165, 0.172],
+ [0.571, 0.148, 0.152],
+ [0.807, 0.215, 0.218],
+ [2.07, 0.228, 0.269],
+ [0.882, 0.21, 0.2],
+ [0.394, 0.159, 0.158],
+ [2.096, 0.343, 0.336],
+ [2.078, 0.329, 0.312],
+ [3.96, 0.656, 0.552],
+ [0.187, 0.059, 0.074],
+ [9.629, 0.361, 0.36],
+ [11.345, 0.481, 0.496],
+ [21.902, 0.818, 0.801],
+ [54.704, 1.082, 1.083],
+ [2.516, 0.121, 0.14],
+ [0.739, 0.103, 0.112],
+ [2.506, 0.151, 0.133],
+ [9.7, 0.439, 0.447],
+ [8.034, 0.507, 0.512],
+ [0.178, 0.11, 0.108],
+ [2.304, 0.178, 0.198],
+ [5.815, 0.232, 0.247],
+ [4.485, 0.814, 0.922],
+ [9.725, 0.627, 0.685],
+ [9.738, 0.578, 0.667],
+ [0.212, 0.132, 0.12],
+ [0.206, 0.112, 0.108],
+ [0.196, 0.084, 0.088],
+ [0.205, 0.068, 0.074],
+ [0.247, 0.114, 0.095],
+ [0.139, 0.057, 0.06],
+ [0.126, 0.056, 0.052],
+ [0.124, 0.052, 0.05]
]
}
+
diff --git a/clickhouse-tencent/results/c6a.2xlarge.json b/clickhouse-tencent/results/c6a.2xlarge.json
index 245efe9ec..a1eadabee 100644
--- a/clickhouse-tencent/results/c6a.2xlarge.json
+++ b/clickhouse-tencent/results/c6a.2xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
"load_time": 283,
- "data_size": 15255081534,
+ "data_size": 15250223791,
"result": [
- [0.002, 0.002, 0.001],
- [0.047, 0.009, 0.009],
- [0.23, 0.041, 0.04],
- [0.876, 0.063, 0.057],
- [1.153, 0.53, 0.525],
- [1.312, 0.635, 0.578],
- [0.028, 0.014, 0.014],
- [0.026, 0.012, 0.011],
- [0.717, 0.65, 0.64],
- [0.849, 0.74, 0.735],
- [0.247, 0.158, 0.158],
- [0.516, 0.187, 0.202],
- [1.373, 0.626, 0.543],
- [1.744, 0.952, 0.883],
- [1.178, 0.691, 0.696],
- [0.572, 0.488, 0.473],
- [2.228, 1.572, 1.584],
- [1.829, 0.621, 0.602],
- [4.436, 2.678, 2.629],
- [0.165, 0.003, 0.003],
- [10.604, 0.46, 0.422],
- [11.567, 0.11, 0.099],
- [14.491, 0.645, 0.645],
- [1.176, 0.081, 0.074],
- [1.56, 0.021, 0.017],
- [1.417, 0.209, 0.205],
- [1.395, 0.02, 0.02],
- [0.891, 0.156, 0.154],
- [11.249, 10.643, 10.673],
- [0.069, 0.042, 0.042],
- [0.953, 0.49, 0.442],
- [3.609, 0.592, 0.593],
- [10.876, 9.838, 9.898],
- [16.272, 8.099, 7.777],
- [15.327, 7.595, 6.766],
- [0.392, 0.332, 0.335],
- [0.069, 0.054, 0.05],
- [0.038, 0.025, 0.025],
- [0.042, 0.019, 0.024],
- [0.126, 0.091, 0.095],
- [0.029, 0.014, 0.014],
- [0.024, 0.012, 0.011],
- [0.02, 0.01, 0.012]
+ [0.003, 0.002, 0.002],
+ [0.038, 0.009, 0.009],
+ [0.285, 0.042, 0.04],
+ [0.901, 0.063, 0.058],
+ [1.203, 0.521, 0.536],
+ [1.286, 0.688, 0.653],
+ [0.03, 0.015, 0.014],
+ [0.027, 0.011, 0.012],
+ [0.836, 0.643, 0.642],
+ [0.849, 0.75, 0.748],
+ [0.243, 0.156, 0.158],
+ [0.565, 0.194, 0.188],
+ [1.411, 0.546, 0.536],
+ [1.837, 0.985, 0.886],
+ [1.124, 0.685, 0.681],
+ [0.565, 0.479, 0.481],
+ [2.233, 1.584, 1.563],
+ [1.865, 0.608, 0.605],
+ [4.444, 2.682, 2.647],
+ [0.25, 0.002, 0.002],
+ [10.608, 0.472, 0.424],
+ [11.575, 0.104, 0.108],
+ [14.438, 0.63, 0.638],
+ [0.995, 0.063, 0.056],
+ [1.585, 0.019, 0.018],
+ [1.409, 0.212, 0.208],
+ [1.351, 0.019, 0.02],
+ [0.897, 0.156, 0.152],
+ [11.258, 10.775, 10.72],
+ [0.065, 0.042, 0.043],
+ [1.035, 0.457, 0.469],
+ [3.65, 0.613, 0.607],
+ [10.8, 9.998, 9.979],
+ [16.096, 7.961, 7.742],
+ [15.451, 6.792, 7.247],
+ [0.409, 0.395, 0.373],
+ [0.094, 0.044, 0.043],
+ [0.048, 0.026, 0.027],
+ [0.057, 0.019, 0.02],
+ [0.174, 0.089, 0.095],
+ [0.04, 0.013, 0.014],
+ [0.03, 0.011, 0.011],
+ [0.026, 0.011, 0.013]
]
}
diff --git a/clickhouse-tencent/results/c6a.4xlarge.json b/clickhouse-tencent/results/c6a.4xlarge.json
index b98e39955..e95b76398 100644
--- a/clickhouse-tencent/results/c6a.4xlarge.json
+++ b/clickhouse-tencent/results/c6a.4xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 232,
- "data_size": 15258871704,
+ "load_time": 215,
+ "data_size": 15254417942,
"result": [
- [0.002, 0.002, 0.002],
- [0.02, 0.007, 0.007],
- [0.045, 0.021, 0.021],
- [0.461, 0.03, 0.029],
- [0.918, 0.401, 0.399],
- [0.658, 0.417, 0.403],
- [0.017, 0.01, 0.011],
- [0.015, 0.009, 0.009],
- [0.519, 0.456, 0.447],
- [0.664, 0.507, 0.503],
- [0.195, 0.143, 0.136],
- [0.436, 0.151, 0.137],
- [1.338, 0.441, 0.45],
- [1.645, 0.652, 0.68],
- [0.928, 0.49, 0.493],
- [0.655, 0.377, 0.393],
- [1.916, 1.226, 1.224],
- [1.547, 0.498, 0.493],
- [4.037, 2.152, 2.234],
- [0.072, 0.003, 0.003],
- [10.195, 0.32, 0.316],
- [11.224, 0.114, 0.11],
- [14.185, 0.692, 0.703],
- [0.858, 0.071, 0.058],
- [1.499, 0.016, 0.015],
- [1.364, 0.181, 0.18],
- [1.273, 0.016, 0.015],
- [0.878, 0.087, 0.086],
- [8.975, 5.41, 5.37],
- [0.061, 0.03, 0.028],
- [0.921, 0.325, 0.31],
- [3.665, 0.538, 0.553],
- [5.354, 3.847, 3.865],
- [11.232, 2.342, 2.294],
- [10.982, 2.301, 2.277],
- [0.3, 0.274, 0.248],
- [0.097, 0.057, 0.059],
- [0.048, 0.035, 0.036],
- [0.063, 0.022, 0.025],
- [0.165, 0.104, 0.107],
- [0.034, 0.016, 0.014],
- [0.028, 0.013, 0.012],
- [0.021, 0.012, 0.01]
+ [0.002, 0.001, 0.001],
+ [0.018, 0.007, 0.007],
+ [0.048, 0.023, 0.022],
+ [0.7, 0.03, 0.029],
+ [0.944, 0.41, 0.406],
+ [0.999, 0.421, 0.4],
+ [0.017, 0.01, 0.009],
+ [0.017, 0.009, 0.009],
+ [0.674, 0.483, 0.478],
+ [1.044, 0.506, 0.544],
+ [0.213, 0.135, 0.134],
+ [0.838, 0.144, 0.133],
+ [1.585, 0.439, 0.443],
+ [2.019, 0.682, 0.674],
+ [1.154, 0.482, 0.518],
+ [0.427, 0.384, 0.389],
+ [2.206, 1.245, 1.244],
+ [1.772, 0.5, 0.509],
+ [4.442, 2.153, 2.152],
+ [0.078, 0.002, 0.002],
+ [10.893, 0.317, 0.311],
+ [12.121, 0.113, 0.118],
+ [14.921, 0.699, 0.693],
+ [1.025, 0.058, 0.052],
+ [1.684, 0.016, 0.015],
+ [1.537, 0.171, 0.17],
+ [1.495, 0.017, 0.017],
+ [0.987, 0.087, 0.084],
+ [9.514, 5.323, 5.354],
+ [0.05, 0.028, 0.028],
+ [1.281, 0.303, 0.32],
+ [4.246, 0.495, 0.522],
+ [5.783, 3.913, 3.836],
+ [11.943, 2.334, 2.32],
+ [11.793, 2.333, 2.254],
+ [0.417, 0.263, 0.267],
+ [0.05, 0.037, 0.037],
+ [0.038, 0.022, 0.022],
+ [0.038, 0.018, 0.016],
+ [0.107, 0.089, 0.086],
+ [0.029, 0.016, 0.013],
+ [0.025, 0.01, 0.01],
+ [0.022, 0.009, 0.009]
]
}
diff --git a/clickhouse-tencent/results/c6a.large.json b/clickhouse-tencent/results/c6a.large.json
index aa1485768..f13103708 100644
--- a/clickhouse-tencent/results/c6a.large.json
+++ b/clickhouse-tencent/results/c6a.large.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c6a.large",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 406,
- "data_size": 15224660889,
+ "load_time": 417,
+ "data_size": 15220638021,
"result": [
- [0.006, 0.002, 0.002],
- [0.157, 0.052, 0.048],
- [0.484, 0.381, 0.337],
- [0.843, 0.382, 0.455],
- [3.829, 2.721, 2.822],
- [4.828, 3.87, 3.873],
- [0.125, 0.069, 0.072],
- [0.128, 0.055, 0.057],
- [5.01, 3.706, 3.915],
- [5.273, 4.883, 4.133],
- [1.21, 0.712, 0.695],
- [1.173, 0.819, 0.805],
- [3.379, 2.328, 2.639],
- [8.164, 8.138, 8.556],
- [3.798, 3.05, 3.024],
- [2.304, 1.899, 1.821],
- [11.884, 12.495, 11.846],
- [3.116, 2.726, 2.713],
- [21.904, 22.463, 21.498],
- [0.446, 0.003, 0.003],
- [10.064, 3.484, 3.258],
- [14.179, 0.969, 0.638],
- [18.122, 6.361, 7.669],
- [2.001, 0.173, 0.172],
- [1.128, 0.063, 0.049],
- [1.498, 1.011, 0.968],
- [1.182, 0.065, 0.057],
- [1.108, 0.767, 0.739],
- [55.46, 43.14, 42.308],
- [0.197, 0.113, 0.113],
- [1.706, 1.431, 1.404],
- [3.669, 4.041, 2.254],
- [28.719, 29.593, 29.444],
- [24.459, 24.343, 24.517],
- [24.393, 25.055, 24.694],
- [1.269, 1.142, 1.038],
- [0.18, 0.113, 0.113],
- [0.084, 0.059, 0.059],
- [0.102, 0.043, 0.045],
- [0.333, 0.23, 0.234],
- [0.049, 0.022, 0.023],
- [0.044, 0.019, 0.019],
- [0.035, 0.019, 0.023]
+ [0.007, 0.002, 0.004],
+ [0.122, 0.041, 0.036],
+ [0.447, 0.18, 0.175],
+ [0.778, 0.418, 0.341],
+ [4.234, 3.099, 3.236],
+ [4.905, 4.03, 3.758],
+ [0.098, 0.099, 0.077],
+ [0.075, 0.056, 0.052],
+ [4.889, 3.915, 4.12],
+ [4.878, 3.421, 3.207],
+ [0.993, 0.666, 0.669],
+ [1.091, 0.793, 0.783],
+ [3.233, 2.3, 2.187],
+ [8.568, 8.492, 8.489],
+ [3.76, 3.158, 2.968],
+ [2.504, 1.965, 1.848],
+ [12.592, 12.467, 12.37],
+ [3.109, 2.713, 2.658],
+ [21.279, 21.745, 21.356],
+ [0.445, 0.004, 0.003],
+ [10.854, 3.377, 3.249],
+ [11.731, 1.092, 0.974],
+ [17.103, 7.681, 6.972],
+ [1.848, 0.247, 0.221],
+ [1.137, 0.061, 0.051],
+ [1.374, 1.002, 0.935],
+ [1.12, 0.058, 0.054],
+ [1.065, 0.769, 0.709],
+ [56.669, 59.097, 43.521],
+ [0.191, 0.111, 0.11],
+ [1.787, 1.421, 1.7],
+ [3.676, 2.224, 2.694],
+ [29.367, 29.87, 29.66],
+ [24.621, 24.249, 24.623],
+ [24.374, 24.474, 24.006],
+ [1.277, 1.058, 1.055],
+ [0.179, 0.13, 0.113],
+ [0.082, 0.059, 0.058],
+ [0.115, 0.042, 0.043],
+ [0.361, 0.228, 0.227],
+ [0.051, 0.022, 0.022],
+ [0.045, 0.019, 0.018],
+ [0.036, 0.024, 0.023]
]
}
diff --git a/clickhouse-tencent/results/c6a.metal.json b/clickhouse-tencent/results/c6a.metal.json
index 2e58f9b73..ad650cbc7 100644
--- a/clickhouse-tencent/results/c6a.metal.json
+++ b/clickhouse-tencent/results/c6a.metal.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 8,
- "data_size": 15260192291,
+ "load_time": 7,
+ "data_size": 15255139626,
"result": [
- [0.003, 0.002, 0.001],
- [0.022, 0.011, 0.009],
- [0.104, 0.013, 0.013],
- [0.276, 0.015, 0.015],
- [0.301, 0.091, 0.08],
- [1.173, 0.111, 0.11],
- [0.022, 0.011, 0.009],
- [0.024, 0.014, 0.013],
- [0.692, 0.291, 0.299],
- [0.949, 0.302, 0.309],
- [0.379, 0.097, 0.094],
- [0.449, 0.103, 0.105],
- [1.196, 0.119, 0.119],
- [2.001, 0.17, 0.172],
- [1.237, 0.131, 0.14],
- [0.426, 0.087, 0.081],
- [2.095, 0.218, 0.225],
- [1.742, 0.076, 0.072],
- [3.649, 0.391, 0.38],
- [0.145, 0.003, 0.002],
- [9.729, 0.072, 0.086],
- [11.37, 0.039, 0.037],
- [14.385, 0.142, 0.128],
- [1.587, 0.055, 0.05],
- [1.45, 0.022, 0.021],
- [1.283, 0.038, 0.039],
- [1.589, 0.017, 0.018],
- [0.781, 0.029, 0.028],
- [8.694, 0.874, 0.859],
- [0.1, 0.033, 0.032],
- [0.347, 0.088, 0.086],
- [3.826, 0.116, 0.114],
- [3.991, 0.856, 0.692],
- [9.63, 0.559, 0.542],
- [9.58, 0.544, 0.551],
- [0.276, 0.056, 0.056],
- [0.106, 0.051, 0.054],
- [0.058, 0.038, 0.035],
- [0.092, 0.026, 0.028],
- [0.233, 0.119, 0.129],
- [0.051, 0.022, 0.022],
- [0.042, 0.015, 0.016],
- [0.033, 0.015, 0.014]
+ [0.003, 0.002, 0.002],
+ [0.026, 0.012, 0.01],
+ [0.037, 0.013, 0.013],
+ [0.257, 0.014, 0.015],
+ [0.732, 0.091, 0.095],
+ [1.327, 0.113, 0.115],
+ [0.017, 0.01, 0.01],
+ [0.02, 0.013, 0.013],
+ [0.904, 0.295, 0.298],
+ [1.072, 0.31, 0.315],
+ [0.345, 0.094, 0.096],
+ [0.705, 0.11, 0.103],
+ [1.292, 0.12, 0.122],
+ [2.043, 0.175, 0.164],
+ [1.245, 0.135, 0.129],
+ [0.243, 0.086, 0.084],
+ [1.867, 0.223, 0.229],
+ [1.353, 0.077, 0.074],
+ [3.462, 0.378, 0.377],
+ [0.053, 0.003, 0.002],
+ [9.406, 0.075, 0.085],
+ [10.785, 0.036, 0.035],
+ [13.902, 0.128, 0.118],
+ [1.062, 0.054, 0.048],
+ [1.291, 0.019, 0.018],
+ [1.135, 0.041, 0.037],
+ [1.408, 0.015, 0.015],
+ [0.643, 0.027, 0.027],
+ [8.437, 0.847, 0.884],
+ [0.052, 0.033, 0.034],
+ [0.191, 0.077, 0.083],
+ [3.619, 0.127, 0.118],
+ [3.677, 0.899, 0.755],
+ [9.537, 0.558, 0.58],
+ [9.436, 0.576, 0.566],
+ [0.089, 0.058, 0.06],
+ [0.085, 0.062, 0.049],
+ [0.046, 0.029, 0.035],
+ [0.051, 0.023, 0.024],
+ [0.14, 0.105, 0.109],
+ [0.033, 0.018, 0.02],
+ [0.03, 0.014, 0.012],
+ [0.025, 0.013, 0.012]
]
}
diff --git a/clickhouse-tencent/results/c6a.xlarge.json b/clickhouse-tencent/results/c6a.xlarge.json
index 4bc87607c..d1a5dd901 100644
--- a/clickhouse-tencent/results/c6a.xlarge.json
+++ b/clickhouse-tencent/results/c6a.xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 310,
- "data_size": 15244501016,
+ "load_time": 321,
+ "data_size": 15244103880,
"result": [
- [0.002, 0.002, 0.002],
- [0.071, 0.015, 0.018],
- [0.412, 0.101, 0.094],
- [1.056, 0.134, 0.166],
- [1.714, 1.064, 1.212],
- [2.317, 1.324, 1.356],
- [0.077, 0.028, 0.028],
- [0.042, 0.022, 0.027],
- [1.901, 1.534, 1.513],
- [1.989, 1.805, 1.735],
- [0.892, 0.36, 0.373],
- [1.015, 0.451, 0.441],
- [1.808, 1.099, 1.048],
- [2.929, 1.815, 1.664],
- [1.96, 1.313, 1.334],
- [0.993, 0.88, 0.867],
- [3.604, 2.948, 2.973],
- [2.266, 1.204, 1.186],
- [10.603, 9.457, 9.536],
- [0.209, 0.003, 0.003],
- [11.114, 0.874, 0.853],
- [12.686, 0.2, 0.2],
- [15.767, 1.223, 1.206],
- [1.875, 0.126, 0.082],
- [1.709, 0.03, 0.029],
- [1.529, 0.429, 0.422],
- [1.243, 0.031, 0.027],
- [0.956, 0.314, 0.318],
- [23.671, 22.84, 22.699],
- [0.154, 0.11, 0.098],
- [1.092, 0.852, 0.862],
- [4.175, 1.192, 1.121],
- [18.195, 18.34, 17.963],
- [21.912, 18.926, 19.221],
- [23.698, 17.976, 17.941],
- [1.018, 0.675, 0.647],
- [0.113, 0.077, 0.069],
- [0.062, 0.044, 0.048],
- [0.074, 0.038, 0.034],
- [0.217, 0.151, 0.159],
- [0.045, 0.018, 0.02],
- [0.03, 0.014, 0.017],
- [0.023, 0.017, 0.015]
+ [0.003, 0.002, 0.002],
+ [0.074, 0.025, 0.027],
+ [0.294, 0.097, 0.103],
+ [1.116, 0.169, 0.153],
+ [1.698, 1.202, 1.475],
+ [1.965, 1.353, 1.353],
+ [0.039, 0.032, 0.075],
+ [0.043, 0.023, 0.021],
+ [1.902, 1.454, 1.301],
+ [1.609, 1.452, 1.411],
+ [0.448, 0.299, 0.297],
+ [0.484, 0.378, 0.357],
+ [1.362, 1.022, 0.995],
+ [2.352, 1.797, 1.649],
+ [1.784, 1.384, 1.456],
+ [1.007, 0.859, 0.896],
+ [3.537, 2.998, 2.879],
+ [2.09, 1.196, 1.219],
+ [10.173, 9.239, 9.144],
+ [0.209, 0.002, 0.003],
+ [10.56, 0.872, 0.859],
+ [12.058, 0.202, 0.187],
+ [15.042, 1.197, 1.207],
+ [1.291, 0.088, 0.081],
+ [1.59, 0.028, 0.026],
+ [1.455, 0.426, 0.418],
+ [1.093, 0.029, 0.025],
+ [0.926, 0.314, 0.316],
+ [23.659, 22.583, 22.503],
+ [0.109, 0.071, 0.073],
+ [0.977, 0.84, 0.85],
+ [4.035, 1.154, 1.14],
+ [18.047, 17.871, 17.928],
+ [21.289, 18.124, 17.897],
+ [21.123, 17.473, 18.127],
+ [0.921, 0.662, 0.647],
+ [0.111, 0.076, 0.072],
+ [0.063, 0.045, 0.043],
+ [0.071, 0.036, 0.034],
+ [0.207, 0.146, 0.149],
+ [0.036, 0.018, 0.019],
+ [0.033, 0.016, 0.016],
+ [0.026, 0.023, 0.02]
]
}
diff --git a/clickhouse-tencent/results/c7a.metal-48xl.json b/clickhouse-tencent/results/c7a.metal-48xl.json
index 31e392e6c..eb0ed4d1a 100644
--- a/clickhouse-tencent/results/c7a.metal-48xl.json
+++ b/clickhouse-tencent/results/c7a.metal-48xl.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse (TCHouse-C)",
- "date": "2025-09-10",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
"load_time": 5,
- "data_size": 15252496294,
+ "data_size": 15251226785,
"result": [
[0.002, 0.002, 0.002],
- [0.021, 0.014, 0.011],
- [0.041, 0.013, 0.013],
- [0.077, 0.018, 0.013],
- [0.247, 0.052, 0.055],
- [1.091, 0.066, 0.067],
- [0.014, 0.01, 0.01],
- [0.022, 0.017, 0.016],
- [0.392, 0.278, 0.277],
- [0.616, 0.285, 0.288],
- [0.185, 0.096, 0.077],
- [0.211, 0.1, 0.101],
- [0.855, 0.071, 0.086],
- [1.802, 0.115, 0.131],
- [1.008, 0.082, 0.078],
- [0.321, 0.057, 0.055],
- [1.892, 0.121, 0.123],
- [1.604, 0.047, 0.048],
- [3.388, 0.196, 0.188],
- [0.055, 0.003, 0.002],
- [9.467, 0.056, 0.053],
- [10.95, 0.035, 0.033],
- [13.924, 0.081, 0.078],
- [1.557, 0.054, 0.054],
- [1.405, 0.019, 0.014],
- [1.135, 0.028, 0.028],
- [1.607, 0.015, 0.013],
- [0.661, 0.025, 0.035],
- [8.347, 0.459, 0.451],
- [0.066, 0.045, 0.042],
- [0.202, 0.065, 0.065],
- [3.676, 0.076, 0.075],
- [3.649, 0.321, 0.315],
- [9.321, 0.294, 0.29],
- [9.335, 0.281, 0.272],
- [0.081, 0.049, 0.043],
- [0.037, 0.023, 0.024],
- [0.028, 0.019, 0.019],
- [0.034, 0.018, 0.016],
- [0.069, 0.135, 0.141],
- [0.026, 0.014, 0.014],
- [0.023, 0.013, 0.012],
- [0.018, 0.011, 0.01]
+ [0.022, 0.012, 0.011],
+ [0.041, 0.013, 0.08],
+ [0.44, 0.012, 0.011],
+ [0.729, 0.062, 0.052],
+ [1.374, 0.064, 0.063],
+ [0.017, 0.01, 0.01],
+ [0.022, 0.014, 0.015],
+ [1.045, 0.274, 0.276],
+ [1.257, 0.283, 0.279],
+ [0.47, 0.098, 0.096],
+ [0.761, 0.105, 0.105],
+ [1.331, 0.071, 0.071],
+ [2.06, 0.113, 0.11],
+ [1.426, 0.083, 0.078],
+ [0.664, 0.061, 0.058],
+ [2.178, 0.13, 0.119],
+ [2.011, 0.048, 0.05],
+ [3.676, 0.19, 0.186],
+ [0.162, 0.002, 0.003],
+ [10.205, 0.06, 0.105],
+ [11.35, 0.034, 0.032],
+ [14.477, 0.082, 0.078],
+ [2.35, 0.064, 0.061],
+ [1.836, 0.014, 0.015],
+ [1.369, 0.027, 0.025],
+ [1.834, 0.014, 0.015],
+ [0.841, 0.026, 0.023],
+ [8.546, 0.536, 0.514],
+ [0.072, 0.042, 0.041],
+ [0.216, 0.078, 0.064],
+ [3.647, 0.093, 0.071],
+ [3.633, 0.34, 0.329],
+ [9.385, 0.281, 0.28],
+ [9.461, 0.29, 0.286],
+ [0.108, 0.048, 0.054],
+ [0.087, 0.044, 0.046],
+ [0.042, 0.027, 0.027],
+ [0.054, 0.022, 0.023],
+ [0.153, 0.119, 0.114],
+ [0.069, 0.019, 0.022],
+ [0.032, 0.016, 0.015],
+ [0.026, 0.013, 0.014]
]
}
diff --git a/clickhouse-web/results/c6a.2xlarge.json b/clickhouse-web/results/c6a.2xlarge.json
index d06cbc770..df4a4d154 100644
--- a/clickhouse-web/results/c6a.2xlarge.json
+++ b/clickhouse-web/results/c6a.2xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (web)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14557009492,
"result": [
- [0.002, 0.001, 0.001],
- [0.124, 0.015, 0.014],
- [0.254, 0.042, 0.043],
- [0.338, 0.055, 0.056],
- [0.86, 0.526, 0.512],
- [1.194, 0.752, 0.754],
- [0.083, 0.014, 0.012],
- [0.065, 0.017, 0.018],
- [1.025, 0.631, 0.655],
- [1.13, 0.708, 0.713],
- [0.816, 0.192, 0.184],
- [0.909, 0.228, 0.224],
- [1.234, 0.767, 0.745],
- [2.089, 1.161, 1.167],
- [1.591, 0.909, 0.829],
- [0.891, 0.474, 0.473],
- [3.34, 2.229, 2.248],
- [1.996, 1.271, 1.248],
- [6.01, 4.481, 4.557],
- [0.929, 0.007, 0.007],
- [6.235, 0.47, 0.462],
- [6.524, 0.115, 0.111],
- [7.016, 0.65, 0.664],
- [15.964, 0.649, 0.616],
- [1.586, 0.305, 0.297],
- [0.774, 0.235, 0.236],
- [1.387, 0.3, 0.301],
- [6.133, 0.954, 0.886],
- [12.331, 10, 9.965],
- [0.206, 0.044, 0.041],
- [1.633, 0.675, 0.692],
- [3.231, 0.9, 0.918],
- [10.338, 9.216, 9.413],
- [8.898, 3.852, 3.848],
- [8.706, 3.813, 3.815],
- [0.583, 0.377, 0.363],
- [0.185, 0.058, 0.057],
- [0.11, 0.033, 0.033],
- [0.153, 0.028, 0.026],
- [0.277, 0.102, 0.107],
- [0.135, 0.016, 0.015],
- [0.105, 0.015, 0.015],
- [0.086, 0.014, 0.014]
+ [0.002, 0.001, 0.002],
+ [0.117, 0.014, 0.014],
+ [0.257, 0.045, 0.043],
+ [0.36, 0.053, 0.053],
+ [0.8, 0.508, 0.491],
+ [1.358, 0.748, 0.743],
+ [0.069, 0.013, 0.014],
+ [0.069, 0.017, 0.016],
+ [1.276, 0.638, 0.644],
+ [1.11, 0.72, 0.706],
+ [0.908, 0.194, 0.19],
+ [0.908, 0.229, 0.216],
+ [1.419, 0.763, 0.742],
+ [2.008, 1.168, 1.108],
+ [1.615, 0.832, 0.805],
+ [0.921, 0.474, 0.462],
+ [3.357, 2.311, 2.35],
+ [1.986, 1.323, 1.291],
+ [5.756, 4.671, 4.626],
+ [0.916, 0.003, 0.003],
+ [6.342, 0.409, 0.391],
+ [6.649, 0.116, 0.112],
+ [7.281, 0.666, 0.667],
+ [16.283, 0.586, 0.567],
+ [1.765, 0.301, 0.293],
+ [1.134, 0.237, 0.241],
+ [1.424, 0.298, 0.29],
+ [5.759, 0.685, 0.691],
+ [12.531, 10.129, 10.084],
+ [0.194, 0.041, 0.041],
+ [1.274, 0.571, 0.606],
+ [2.214, 0.709, 0.706],
+ [10.744, 9.722, 9.782],
+ [9.004, 4.041, 3.804],
+ [8.824, 3.889, 3.964],
+ [0.574, 0.351, 0.349],
+ [0.191, 0.063, 0.057],
+ [0.138, 0.032, 0.032],
+ [0.169, 0.028, 0.027],
+ [0.259, 0.106, 0.106],
+ [0.125, 0.017, 0.017],
+ [0.1, 0.016, 0.016],
+ [0.162, 0.014, 0.015]
]
}
diff --git a/clickhouse-web/results/c6a.4xlarge.json b/clickhouse-web/results/c6a.4xlarge.json
index 941d36922..771e66b04 100644
--- a/clickhouse-web/results/c6a.4xlarge.json
+++ b/clickhouse-web/results/c6a.4xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (web)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14557009492,
"result": [
- [0.002, 0.001, 0.002],
- [0.188, 0.011, 0.009],
- [0.289, 0.025, 0.025],
- [0.359, 0.031, 0.03],
- [0.516, 0.331, 0.332],
- [0.837, 0.433, 0.423],
- [0.085, 0.01, 0.009],
- [0.06, 0.01, 0.01],
- [0.749, 0.471, 0.433],
- [0.717, 0.478, 0.477],
- [0.504, 0.136, 0.136],
- [0.534, 0.155, 0.161],
- [0.827, 0.549, 0.563],
- [1.257, 0.734, 0.746],
- [1.029, 0.52, 0.568],
- [0.566, 0.386, 0.388],
- [2.19, 1.561, 1.711],
- [1.376, 0.89, 0.899],
- [3.991, 2.934, 2.887],
- [0.85, 0.007, 0.008],
- [4.536, 0.38, 0.382],
- [3.473, 0.115, 0.115],
- [5.47, 0.666, 0.672],
- [29.167, 0.519, 0.5],
- [1.038, 0.168, 0.171],
- [0.465, 0.16, 0.158],
- [0.98, 0.161, 0.166],
- [3.334, 0.775, 0.779],
- [6.287, 5.103, 5.097],
- [0.132, 0.03, 0.03],
- [1.095, 0.413, 0.414],
- [1.988, 0.653, 0.642],
- [4.342, 3.717, 3.664],
- [4.865, 2.71, 2.685],
- [4.892, 2.697, 2.713],
- [0.442, 0.272, 0.271],
- [0.184, 0.041, 0.04],
- [0.131, 0.023, 0.025],
- [0.168, 0.021, 0.022],
- [0.216, 0.079, 0.076],
- [0.148, 0.012, 0.012],
- [0.119, 0.012, 0.011],
- [0.118, 0.012, 0.012]
+ [0.002, 0.001, 0.001],
+ [0.218, 0.01, 0.01],
+ [0.395, 0.028, 0.031],
+ [0.639, 0.032, 0.032],
+ [0.557, 0.34, 0.337],
+ [1.088, 0.432, 0.446],
+ [0.104, 0.009, 0.009],
+ [0.082, 0.01, 0.011],
+ [1.102, 0.463, 0.463],
+ [0.749, 0.477, 0.512],
+ [0.51, 0.134, 0.137],
+ [0.637, 0.159, 0.167],
+ [0.813, 0.535, 0.531],
+ [1.215, 0.737, 0.746],
+ [1.064, 0.531, 0.531],
+ [0.562, 0.391, 0.387],
+ [2.144, 1.606, 1.598],
+ [1.424, 0.931, 0.928],
+ [4.095, 2.952, 2.943],
+ [0.7, 0.003, 0.003],
+ [3.409, 0.356, 0.362],
+ [3.538, 0.113, 0.116],
+ [3.961, 0.684, 0.667],
+ [25.51, 0.485, 0.484],
+ [0.966, 0.162, 0.167],
+ [0.466, 0.156, 0.156],
+ [0.986, 0.166, 0.161],
+ [3.105, 0.375, 0.37],
+ [6.347, 5.136, 5.143],
+ [0.14, 0.031, 0.033],
+ [0.834, 0.356, 0.351],
+ [1.486, 0.573, 0.564],
+ [4.344, 3.759, 3.615],
+ [4.94, 2.644, 2.696],
+ [4.977, 2.693, 2.711],
+ [0.442, 0.258, 0.275],
+ [0.16, 0.043, 0.046],
+ [0.13, 0.024, 0.025],
+ [0.142, 0.023, 0.021],
+ [0.208, 0.084, 0.079],
+ [0.142, 0.015, 0.014],
+ [0.12, 0.013, 0.012],
+ [0.094, 0.013, 0.012]
]
}
diff --git a/clickhouse-web/results/c6a.metal.json b/clickhouse-web/results/c6a.metal.json
index 78198fdc3..8ee417111 100644
--- a/clickhouse-web/results/c6a.metal.json
+++ b/clickhouse-web/results/c6a.metal.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (web)",
- "date": "2025-09-07",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
@@ -10,48 +10,48 @@
"data_size": 14557009492,
"result": [
[0.002, 0.001, 0.001],
- [0.183, 0.014, 0.015],
- [0.625, 0.018, 0.018],
- [0.534, 0.018, 0.019],
- [0.324, 0.176, 0.177],
- [1.274, 0.193, 0.191],
- [0.149, 0.016, 0.014],
- [0.114, 0.017, 0.016],
- [0.737, 0.291, 0.298],
- [0.499, 0.311, 0.309],
- [0.737, 0.107, 0.11],
- [0.681, 0.098, 0.097],
- [0.466, 0.169, 0.171],
- [0.534, 0.243, 0.216],
- [0.589, 0.175, 0.186],
- [0.211, 0.101, 0.092],
- [0.585, 0.345, 0.372],
- [1.413, 0.26, 0.259],
- [1.081, 0.625, 0.71],
- [0.48, 0.007, 0.007],
- [2.12, 0.098, 0.117],
- [1.06, 0.067, 0.064],
- [2.235, 0.228, 0.224],
- [47.173, 0.206, 0.193],
- [0.467, 0.061, 0.061],
- [0.411, 0.052, 0.052],
- [0.435, 0.062, 0.058],
- [1.067, 0.243, 0.231],
- [2.032, 0.774, 0.751],
- [0.238, 0.036, 0.037],
- [0.711, 0.154, 0.154],
- [0.853, 0.233, 0.239],
- [2.035, 0.958, 0.908],
- [1.597, 0.747, 0.745],
- [1.591, 0.78, 0.779],
- [0.181, 0.071, 0.069],
- [0.207, 0.033, 0.039],
- [0.186, 0.025, 0.024],
- [0.241, 0.024, 0.025],
- [0.322, 0.062, 0.065],
- [0.4, 0.018, 0.016],
- [0.217, 0.016, 0.015],
- [0.095, 0.016, 0.015]
+ [0.15, 0.014, 0.013],
+ [0.2, 0.018, 0.016],
+ [0.188, 0.017, 0.017],
+ [0.328, 0.179, 0.175],
+ [0.548, 0.194, 0.18],
+ [0.057, 0.016, 0.014],
+ [0.074, 0.015, 0.017],
+ [0.489, 0.3, 0.29],
+ [0.516, 0.327, 0.313],
+ [0.307, 0.112, 0.111],
+ [0.324, 0.097, 0.101],
+ [0.481, 0.174, 0.168],
+ [0.571, 0.224, 0.239],
+ [0.49, 0.172, 0.172],
+ [0.214, 0.097, 0.09],
+ [1.375, 0.323, 0.37],
+ [0.503, 0.293, 0.258],
+ [1.052, 0.637, 0.683],
+ [0.482, 0.003, 0.004],
+ [1.999, 0.099, 0.118],
+ [1.725, 0.069, 0.064],
+ [1.743, 0.226, 0.223],
+ [30.111, 0.2, 0.168],
+ [0.431, 0.059, 0.059],
+ [0.41, 0.052, 0.046],
+ [0.422, 0.058, 0.06],
+ [1.197, 0.113, 0.116],
+ [1.327, 0.752, 0.783],
+ [0.144, 0.036, 0.037],
+ [1.201, 0.115, 0.107],
+ [1.326, 0.204, 0.175],
+ [1.151, 0.906, 0.832],
+ [1.511, 0.718, 0.705],
+ [1.51, 0.744, 0.664],
+ [0.178, 0.065, 0.066],
+ [0.144, 0.041, 0.034],
+ [0.106, 0.024, 0.023],
+ [0.147, 0.026, 0.021],
+ [0.259, 0.066, 0.076],
+ [0.113, 0.016, 0.018],
+ [0.11, 0.016, 0.016],
+ [0.105, 0.016, 0.016]
]
}
diff --git a/clickhouse-web/results/c6a.xlarge.json b/clickhouse-web/results/c6a.xlarge.json
index 604d724b4..c86569ad4 100644
--- a/clickhouse-web/results/c6a.xlarge.json
+++ b/clickhouse-web/results/c6a.xlarge.json
@@ -1,6 +1,6 @@
{
"system": "ClickHouse (web)",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
@@ -9,49 +9,49 @@
"load_time": 0,
"data_size": 14557009492,
"result": [
- [0.002, 0.001, 0.001],
- [0.147, 0.02, 0.021],
- [0.293, 0.076, 0.075],
- [0.562, 0.099, 0.097],
- [1.234, 0.811, 0.809],
- [2.188, 1.358, 1.346],
- [0.058, 0.019, 0.019],
- [0.06, 0.025, 0.023],
- [1.64, 1.065, 1.162],
- [1.819, 1.212, 1.215],
- [1.418, 0.326, 0.323],
- [1.891, 0.382, 0.392],
- [2.069, 1.339, 1.338],
- [3.49, 2.046, 1.981],
- [2.689, 1.483, 1.484],
- [1.268, 0.947, 0.827],
- [5.72, 4.231, 4.349],
- [5.77, 2.464, 2.368],
- [15.023, 13.613, 13.347],
- [0.824, 0.007, 0.007],
- [12.059, 0.871, 0.862],
- [12.656, 0.204, 0.196],
- [13.885, 4.859, 2.729],
- [25.009, 6.801, 6.384],
- [4.209, 0.579, 0.587],
- [1.133, 0.473, 0.473],
- [2.628, 0.586, 0.576],
- [12.275, 1.757, 1.815],
- [24.365, 19.857, 19.752],
- [0.23, 0.069, 0.067],
- [2.928, 1.2, 1.188],
- [6.263, 1.494, 1.539],
- [17.189, 15.068, 15.176],
- [24.764, 15.87, 14.992],
- [24.089, 14.122, 16.311],
- [1.046, 0.6, 0.59],
- [0.264, 0.077, 0.079],
- [0.162, 0.04, 0.038],
- [0.204, 0.032, 0.03],
- [0.397, 0.137, 0.142],
- [0.175, 0.018, 0.019],
- [0.131, 0.018, 0.02],
- [0.091, 0.018, 0.019]
+ [0.002, 0.002, 0.001],
+ [0.117, 0.021, 0.021],
+ [0.283, 0.078, 0.077],
+ [0.536, 0.101, 0.101],
+ [1.226, 0.801, 0.824],
+ [2.048, 1.402, 1.371],
+ [0.069, 0.02, 0.019],
+ [0.053, 0.024, 0.023],
+ [1.705, 1.105, 1.178],
+ [1.871, 1.25, 1.262],
+ [1.425, 0.328, 0.32],
+ [1.529, 0.38, 0.381],
+ [2.091, 1.337, 1.31],
+ [3.402, 1.988, 1.983],
+ [2.678, 1.453, 1.44],
+ [1.555, 0.915, 0.872],
+ [7.505, 4.361, 4.073],
+ [5.653, 2.357, 2.204],
+ [14.613, 13.508, 13.674],
+ [0.889, 0.003, 0.003],
+ [11.998, 0.751, 0.707],
+ [12.844, 0.203, 0.19],
+ [14.077, 5.664, 3.079],
+ [26.249, 7.07, 6.43],
+ [2.537, 0.57, 0.575],
+ [1.088, 0.437, 0.435],
+ [2.476, 0.583, 0.563],
+ [11.419, 1.327, 1.337],
+ [24.912, 20.275, 19.989],
+ [0.291, 0.068, 0.069],
+ [2.215, 1.017, 1.022],
+ [4.393, 1.275, 1.318],
+ [16.97, 15.603, 15.596],
+ [24.318, 14.577, 15.002],
+ [23.725, 15.786, 15.865],
+ [1.088, 0.613, 0.594],
+ [0.22, 0.082, 0.081],
+ [0.114, 0.05, 0.04],
+ [0.207, 0.032, 0.032],
+ [0.336, 0.159, 0.134],
+ [0.15, 0.02, 0.02],
+ [0.13, 0.019, 0.019],
+ [0.171, 0.019, 0.019]
]
}
diff --git a/clickhouse-web/results/c7a.metal-48xl.json b/clickhouse-web/results/c7a.metal-48xl.json
index ed3b246bd..f3b002e40 100644
--- a/clickhouse-web/results/c7a.metal-48xl.json
+++ b/clickhouse-web/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (web)",
- "date": "2025-08-30",
+ "system": "ClickHouse (web)",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
"load_time": 0,
"data_size": 14557009492,
"result": [
[0.002, 0.001, 0.001],
- [0.187, 0.02, 0.019],
- [0.322, 0.021, 0.021],
- [0.518, 0.02, 0.021],
- [0.493, 0.332, 0.326],
- [0.718, 0.335, 0.331],
- [0.053, 0.022, 0.019],
- [0.087, 0.02, 0.023],
- [0.785, 0.293, 0.276],
- [0.468, 0.283, 0.286],
- [0.697, 0.123, 0.119],
- [0.565, 0.099, 0.1],
- [0.383, 0.099, 0.097],
- [0.352, 0.141, 0.127],
- [0.34, 0.086, 0.084],
- [0.192, 0.056, 0.054],
- [0.355, 0.142, 0.141],
- [0.317, 0.117, 0.114],
- [0.787, 0.269, 0.265],
- [0.447, 0.007, 0.007],
- [1.181, 0.05, 0.05],
- [1.547, 0.049, 0.046],
- [1.817, 0.114, 0.109],
- [33.655, 0.173, 0.147],
- [0.274, 0.042, 0.044],
- [0.233, 0.033, 0.034],
- [1.186, 0.047, 0.044],
- [1.603, 0.144, 0.14],
- [1.482, 0.455, 0.437],
- [0.171, 0.047, 0.049],
- [0.502, 0.097, 0.099],
- [1.423, 0.122, 0.119],
- [1.523, 0.324, 0.306],
- [1.516, 0.311, 0.314],
- [1.62, 0.306, 0.3],
- [0.184, 0.049, 0.049],
- [0.142, 0.029, 0.028],
- [0.096, 0.02, 0.02],
- [0.15, 0.018, 0.019],
- [0.264, 0.059, 0.053],
- [0.168, 0.016, 0.016],
- [0.148, 0.014, 0.014],
- [0.129, 0.013, 0.014]
+ [0.179, 0.019, 0.02],
+ [0.218, 0.022, 0.022],
+ [0.255, 0.021, 0.021],
+ [0.474, 0.342, 0.338],
+ [0.559, 0.357, 0.332],
+ [0.059, 0.024, 0.02],
+ [0.11, 0.023, 0.023],
+ [0.519, 0.299, 0.294],
+ [0.517, 0.292, 0.302],
+ [0.561, 0.126, 0.126],
+ [0.372, 0.099, 0.099],
+ [0.311, 0.103, 0.098],
+ [0.388, 0.134, 0.141],
+ [0.314, 0.09, 0.089],
+ [0.189, 0.056, 0.057],
+ [0.412, 0.17, 0.152],
+ [0.355, 0.118, 0.124],
+ [0.66, 0.278, 0.27],
+ [0.441, 0.003, 0.003],
+ [1.638, 0.048, 0.05],
+ [1.756, 0.045, 0.044],
+ [1.942, 0.129, 0.113],
+ [12.132, 0.17, 0.138],
+ [0.342, 0.041, 0.04],
+ [0.215, 0.034, 0.037],
+ [0.289, 0.044, 0.041],
+ [1.473, 0.078, 0.077],
+ [1.315, 0.465, 0.466],
+ [0.2, 0.052, 0.051],
+ [0.279, 0.092, 0.096],
+ [1.357, 0.104, 0.097],
+ [1.577, 0.322, 0.326],
+ [1.627, 0.331, 0.324],
+ [1.593, 0.327, 0.324],
+ [0.207, 0.05, 0.05],
+ [0.155, 0.029, 0.03],
+ [0.065, 0.021, 0.021],
+ [0.153, 0.02, 0.02],
+ [0.237, 0.052, 0.055],
+ [0.114, 0.018, 0.016],
+ [0.122, 0.017, 0.016],
+ [0.115, 0.016, 0.016]
]
}
+
diff --git a/clickhouse-web/results/c8g.4xlarge.json b/clickhouse-web/results/c8g.4xlarge.json
index fc3204fe5..e35abd36f 100644
--- a/clickhouse-web/results/c8g.4xlarge.json
+++ b/clickhouse-web/results/c8g.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (web)",
- "date": "2025-08-30",
+ "system": "ClickHouse (web)",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
"load_time": 0,
"data_size": 14557009492,
"result": [
- [0.001, 0.001, 0.001],
- [0.127, 0.01, 0.009],
- [0.215, 0.02, 0.021],
- [0.261, 0.027, 0.029],
- [0.379, 0.17, 0.165],
- [0.598, 0.278, 0.275],
- [0.055, 0.01, 0.008],
- [0.063, 0.01, 0.009],
- [0.49, 0.22, 0.225],
- [0.544, 0.249, 0.253],
- [0.483, 0.094, 0.094],
- [0.54, 0.123, 0.117],
- [0.58, 0.286, 0.261],
- [0.948, 0.369, 0.369],
- [0.852, 0.319, 0.302],
- [0.392, 0.156, 0.156],
- [1.421, 0.725, 0.715],
- [0.934, 0.402, 0.408],
- [1.964, 1.173, 1.199],
- [0.466, 0.007, 0.007],
- [3.32, 0.188, 0.196],
- [3.44, 0.049, 0.048],
- [3.861, 0.25, 0.249],
- [12.66, 0.292, 0.287],
- [0.956, 0.119, 0.118],
- [0.411, 0.097, 0.099],
- [1.279, 0.119, 0.12],
- [3.301, 0.347, 0.342],
- [4.392, 2.681, 2.691],
- [0.171, 0.027, 0.026],
- [1.512, 0.257, 0.236],
- [1.851, 0.301, 0.309],
- [1.9, 1.021, 0.992],
- [4.042, 1.187, 1.15],
- [4.049, 1.184, 1.127],
- [0.301, 0.115, 0.112],
- [0.163, 0.026, 0.025],
- [0.09, 0.016, 0.016],
- [0.143, 0.015, 0.015],
- [0.206, 0.041, 0.041],
- [0.105, 0.01, 0.01],
- [0.101, 0.01, 0.01],
- [0.11, 0.009, 0.009]
+ [0.002, 0.001, 0.001],
+ [0.127, 0.011, 0.01],
+ [0.214, 0.021, 0.021],
+ [1.181, 0.028, 0.028],
+ [1.213, 0.173, 0.169],
+ [0.664, 0.306, 0.309],
+ [0.052, 0.009, 0.008],
+ [0.038, 0.01, 0.01],
+ [1.26, 0.245, 0.247],
+ [1.226, 0.28, 0.275],
+ [0.503, 0.106, 0.106],
+ [0.538, 0.132, 0.132],
+ [1.213, 0.281, 0.291],
+ [1.246, 0.409, 0.398],
+ [0.834, 0.319, 0.312],
+ [0.35, 0.16, 0.159],
+ [1.417, 0.696, 0.696],
+ [0.955, 0.445, 0.441],
+ [2.082, 1.277, 1.258],
+ [0.486, 0.003, 0.003],
+ [3.291, 0.201, 0.212],
+ [3.401, 0.054, 0.054],
+ [3.7, 0.28, 0.285],
+ [12.481, 0.317, 0.309],
+ [1.178, 0.125, 0.125],
+ [1.131, 0.103, 0.103],
+ [1.131, 0.128, 0.125],
+ [3.05, 0.269, 0.268],
+ [4.353, 2.767, 2.774],
+ [0.224, 0.028, 0.028],
+ [0.772, 0.21, 0.204],
+ [1.22, 0.283, 0.258],
+ [1.868, 1.088, 1.091],
+ [3.956, 1.228, 1.225],
+ [4.172, 1.231, 1.232],
+ [0.314, 0.15, 0.146],
+ [0.147, 0.029, 0.029],
+ [0.107, 0.018, 0.018],
+ [0.143, 0.017, 0.017],
+ [0.218, 0.045, 0.046],
+ [0.119, 0.012, 0.012],
+ [0.108, 0.011, 0.011],
+ [0.117, 0.01, 0.01]
]
}
+
diff --git a/clickhouse-web/results/c8g.metal-48xl.json b/clickhouse-web/results/c8g.metal-48xl.json
index ac18b3ff2..a14b4d99e 100644
--- a/clickhouse-web/results/c8g.metal-48xl.json
+++ b/clickhouse-web/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse (web)",
- "date": "2025-08-30",
+ "system": "ClickHouse (web)",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","ClickHouse derivative","serverless","stateless"],
"load_time": 0,
"data_size": 14557009492,
"result": [
[0.001, 0.001, 0.001],
- [0.14, 0.013, 0.013],
- [0.184, 0.014, 0.013],
- [0.205, 0.014, 0.013],
- [0.328, 0.296, 0.223],
- [0.485, 0.272, 0.27],
- [0.061, 0.016, 0.014],
- [0.095, 0.02, 0.02],
- [0.394, 0.194, 0.195],
- [0.421, 0.199, 0.199],
- [0.412, 0.084, 0.086],
- [0.3, 0.073, 0.072],
- [0.263, 0.081, 0.081],
- [0.326, 0.105, 0.107],
- [0.278, 0.08, 0.079],
- [0.206, 0.051, 0.048],
- [0.382, 0.15, 0.147],
- [0.336, 0.117, 0.118],
- [0.566, 0.298, 0.254],
- [0.378, 0.008, 0.007],
- [1.684, 0.061, 0.057],
- [1.453, 0.037, 0.038],
- [1.811, 0.103, 0.099],
- [10.642, 0.169, 0.166],
- [0.336, 0.038, 0.037],
- [0.217, 0.033, 0.031],
- [0.267, 0.04, 0.041],
- [1.736, 0.123, 0.118],
- [1.297, 0.382, 0.38],
- [0.2, 0.062, 0.062],
- [0.339, 0.075, 0.075],
- [1.406, 0.102, 0.098],
- [1.562, 0.344, 0.285],
- [1.583, 0.269, 0.258],
- [1.6, 0.266, 0.27],
- [0.187, 0.043, 0.044],
- [0.146, 0.032, 0.032],
- [0.086, 0.022, 0.02],
- [0.143, 0.021, 0.019],
- [0.21, 0.056, 0.046],
- [0.132, 0.016, 0.015],
- [0.142, 0.015, 0.015],
- [0.122, 0.013, 0.013]
+ [0.177, 0.013, 0.012],
+ [0.187, 0.014, 0.014],
+ [0.224, 0.013, 0.014],
+ [0.327, 0.205, 0.31],
+ [0.516, 0.246, 0.287],
+ [0.048, 0.016, 0.014],
+ [0.086, 0.017, 0.017],
+ [0.436, 0.205, 0.203],
+ [0.412, 0.213, 0.212],
+ [0.29, 0.085, 0.086],
+ [0.283, 0.074, 0.074],
+ [0.249, 0.08, 0.079],
+ [0.326, 0.104, 0.101],
+ [0.298, 0.075, 0.077],
+ [0.187, 0.048, 0.049],
+ [0.373, 0.146, 0.146],
+ [1.195, 0.114, 0.114],
+ [0.563, 0.262, 0.255],
+ [0.426, 0.002, 0.002],
+ [1.508, 0.062, 0.054],
+ [1.505, 0.039, 0.038],
+ [1.799, 0.099, 0.098],
+ [23.493, 0.173, 0.168],
+ [0.304, 0.037, 0.038],
+ [0.193, 0.032, 0.033],
+ [1.215, 0.039, 0.039],
+ [1.313, 0.066, 0.066],
+ [1.451, 0.385, 0.39],
+ [0.203, 0.065, 0.064],
+ [0.426, 0.067, 0.065],
+ [0.662, 0.08, 0.077],
+ [0.706, 0.263, 0.26],
+ [1.793, 0.258, 0.258],
+ [1.539, 0.259, 0.255],
+ [0.175, 0.044, 0.042],
+ [0.136, 0.03, 0.032],
+ [0.123, 0.021, 0.022],
+ [0.156, 0.021, 0.021],
+ [0.253, 0.049, 0.048],
+ [0.207, 0.015, 0.015],
+ [0.132, 0.015, 0.015],
+ [0.101, 0.014, 0.014]
]
}
+
diff --git a/clickhouse/results/c6a.2xlarge.json b/clickhouse/results/c6a.2xlarge.json
index f2d5722b7..66f36354f 100644
--- a/clickhouse/results/c6a.2xlarge.json
+++ b/clickhouse/results/c6a.2xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.2xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
"load_time": 275,
- "data_size": 14465711160,
+ "data_size": 14463145748,
"result": [
- [0.002, 0.001, 0.001],
- [0.04, 0.009, 0.008],
- [0.168, 0.04, 0.044],
- [0.898, 0.061, 0.058],
- [0.968, 0.542, 0.555],
- [1.238, 0.774, 0.799],
- [0.036, 0.014, 0.014],
- [0.035, 0.012, 0.012],
- [0.783, 0.649, 0.646],
- [0.898, 0.733, 0.745],
- [0.247, 0.156, 0.158],
- [0.505, 0.183, 0.18],
- [1.382, 0.791, 0.78],
- [1.869, 1.213, 1.161],
- [1.151, 0.912, 0.858],
- [0.735, 0.489, 0.493],
- [3.035, 2.379, 2.432],
- [2.065, 1.341, 1.347],
- [5.878, 4.862, 4.782],
- [0.198, 0.004, 0.004],
- [9.918, 0.467, 0.446],
- [10.743, 0.105, 0.103],
- [13.119, 0.642, 0.627],
- [6.812, 1.262, 1.268],
- [2.579, 0.296, 0.277],
- [0.973, 0.233, 0.232],
- [2.476, 0.281, 0.283],
- [9.524, 0.937, 0.913],
- [11.258, 10.508, 10.495],
- [0.071, 0.045, 0.046],
- [2.118, 0.647, 0.643],
- [4.763, 0.834, 0.782],
- [10.721, 9.894, 9.919],
- [10.852, 4.182, 4.17],
- [11.007, 4.188, 4.047],
- [0.391, 0.343, 0.35],
- [0.084, 0.064, 0.058],
- [0.039, 0.026, 0.028],
- [0.052, 0.019, 0.02],
- [0.134, 0.096, 0.101],
- [0.029, 0.016, 0.013],
- [0.029, 0.011, 0.011],
- [0.022, 0.012, 0.01]
+ [0.002, 0.002, 0.002],
+ [0.028, 0.009, 0.008],
+ [0.125, 0.04, 0.04],
+ [0.616, 0.056, 0.055],
+ [0.918, 0.582, 0.526],
+ [1.251, 0.78, 0.772],
+ [0.025, 0.014, 0.013],
+ [0.025, 0.011, 0.011],
+ [0.732, 0.648, 0.649],
+ [0.898, 0.745, 0.776],
+ [0.247, 0.156, 0.155],
+ [0.525, 0.182, 0.187],
+ [1.39, 0.775, 0.773],
+ [1.952, 1.156, 1.157],
+ [1.265, 0.834, 0.838],
+ [0.709, 0.488, 0.497],
+ [2.925, 2.355, 2.363],
+ [2.094, 1.307, 1.311],
+ [5.837, 4.789, 4.757],
+ [0.201, 0.002, 0.003],
+ [9.911, 0.396, 0.374],
+ [10.829, 0.1, 0.102],
+ [13.186, 0.635, 0.621],
+ [6.67, 0.559, 0.545],
+ [2.166, 0.286, 0.274],
+ [0.819, 0.23, 0.226],
+ [2.458, 0.274, 0.27],
+ [9.568, 0.698, 0.686],
+ [11.264, 10.634, 10.586],
+ [0.067, 0.043, 0.041],
+ [2.167, 0.579, 0.569],
+ [4.807, 0.716, 0.688],
+ [10.776, 10.087, 9.87],
+ [11.257, 3.991, 3.948],
+ [11.029, 3.979, 3.99],
+ [0.389, 0.346, 0.362],
+ [0.107, 0.059, 0.059],
+ [0.049, 0.029, 0.028],
+ [0.059, 0.024, 0.024],
+ [0.181, 0.1, 0.115],
+ [0.032, 0.015, 0.014],
+ [0.027, 0.011, 0.011],
+ [0.023, 0.01, 0.01]
]
}
diff --git a/clickhouse/results/c6a.4xlarge.json b/clickhouse/results/c6a.4xlarge.json
index 540f80f2d..b5a4fcb44 100644
--- a/clickhouse/results/c6a.4xlarge.json
+++ b/clickhouse/results/c6a.4xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.4xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 221,
- "data_size": 14470042218,
+ "load_time": 220,
+ "data_size": 14462139925,
"result": [
- [0.002, 0.001, 0.001],
- [0.018, 0.006, 0.006],
- [0.043, 0.021, 0.021],
- [0.578, 0.029, 0.028],
- [0.829, 0.344, 0.341],
- [0.714, 0.455, 0.446],
- [0.02, 0.009, 0.009],
- [0.021, 0.008, 0.008],
- [0.513, 0.44, 0.463],
- [0.619, 0.507, 0.492],
- [0.191, 0.13, 0.133],
- [0.377, 0.141, 0.15],
- [1.211, 0.542, 0.536],
- [1.554, 0.8, 0.789],
- [0.864, 0.601, 0.569],
- [0.456, 0.38, 0.387],
- [2.101, 1.636, 1.616],
- [1.668, 0.937, 0.923],
- [4.678, 3.045, 3.025],
- [0.216, 0.004, 0.004],
- [9.685, 0.343, 0.334],
- [10.469, 0.107, 0.107],
- [12.873, 0.649, 0.639],
- [6.166, 0.982, 1.034],
- [2.265, 0.164, 0.16],
- [1.067, 0.147, 0.149],
- [2.532, 0.164, 0.162],
- [9.447, 0.689, 0.694],
- [7.788, 5.224, 5.238],
- [0.058, 0.027, 0.027],
- [2.246, 0.415, 0.442],
- [4.658, 0.616, 0.603],
- [5.456, 3.855, 3.791],
- [10.698, 2.856, 2.841],
- [10.546, 2.865, 2.873],
- [0.304, 0.262, 0.26],
- [0.096, 0.067, 0.063],
- [0.041, 0.036, 0.029],
- [0.057, 0.022, 0.022],
- [0.154, 0.114, 0.118],
- [0.039, 0.016, 0.02],
- [0.039, 0.012, 0.012],
- [0.03, 0.011, 0.011]
+ [0.002, 0.002, 0.002],
+ [0.017, 0.007, 0.006],
+ [0.045, 0.022, 0.021],
+ [0.431, 0.035, 0.03],
+ [0.83, 0.345, 0.346],
+ [0.636, 0.426, 0.428],
+ [0.016, 0.009, 0.01],
+ [0.015, 0.009, 0.009],
+ [0.507, 0.445, 0.5],
+ [0.68, 0.506, 0.508],
+ [0.187, 0.124, 0.126],
+ [0.461, 0.148, 0.145],
+ [1.262, 0.543, 0.548],
+ [1.593, 0.821, 0.797],
+ [0.886, 0.58, 0.608],
+ [0.464, 0.391, 0.388],
+ [2.107, 1.666, 1.647],
+ [1.616, 0.941, 0.954],
+ [4.75, 3.138, 3.099],
+ [0.173, 0.002, 0.003],
+ [9.69, 0.333, 0.317],
+ [10.512, 0.112, 0.108],
+ [12.877, 0.689, 0.69],
+ [6.193, 0.453, 0.45],
+ [2.041, 0.156, 0.156],
+ [0.93, 0.14, 0.141],
+ [2.474, 0.157, 0.153],
+ [9.422, 0.377, 0.366],
+ [7.977, 5.337, 5.266],
+ [0.051, 0.029, 0.027],
+ [2.124, 0.367, 0.372],
+ [4.73, 0.542, 0.603],
+ [5.465, 3.963, 3.96],
+ [10.771, 2.959, 2.966],
+ [10.628, 2.96, 2.919],
+ [0.307, 0.283, 0.277],
+ [0.056, 0.046, 0.046],
+ [0.038, 0.021, 0.021],
+ [0.036, 0.018, 0.017],
+ [0.103, 0.085, 0.083],
+ [0.03, 0.012, 0.012],
+ [0.024, 0.009, 0.009],
+ [0.02, 0.008, 0.009]
]
}
diff --git a/clickhouse/results/c6a.large.json b/clickhouse/results/c6a.large.json
index 9497d234a..bfb28e488 100644
--- a/clickhouse/results/c6a.large.json
+++ b/clickhouse/results/c6a.large.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.large",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 426,
- "data_size": 14427778058,
+ "load_time": 410,
+ "data_size": 14430433955,
"result": [
- [0.015, 0.007, 0.006],
- [0.208, 0.043, 0.046],
- [0.466, 0.217, 0.253],
- [0.862, 0.381, 0.287],
- [3.658, 2.317, 2.363],
- [5.301, 3.619, 3.333],
- [0.063, 0.043, 0.042],
- [0.068, 0.033, 0.032],
- [3.205, 2.635, 2.873],
- [3.576, 3.115, 3.121],
- [1.003, 0.628, 0.633],
- [1.391, 0.784, 0.762],
- [4.257, 3.483, 3.494],
- [9.796, 9.338, 9.427],
- [7.139, 6.802, 7.021],
- [2.938, 1.884, 1.878],
- [17.899, 17.525, 17.565],
- [13.063, 12.741, 12.829],
- [37.234, 36.508, 37.449],
- [0.452, 0.011, 0.015],
- [12.3, 3.644, 3.657],
- [13.008, 0.725, 0.735],
- [13.48, 5.026, 5.45],
- [7.707, 3.398, 4.188],
- [2.222, 2.087, 0.99],
- [1.261, 0.824, 1.001],
- [2.009, 1.034, 0.998],
- [8.504, 4.776, 4.324],
- [42.399, 41.022, 41.236],
- [0.195, 0.109, 0.11],
- [2.959, 2.212, 2.106],
- [4.795, 3.371, 4.53],
- [30.25, 30.631, 30.964],
- [29.403, 29.711, 29.427],
- [29.57, 29.538, 29.383],
- [1.316, 1.045, 1.04],
- [0.206, 0.141, 0.159],
- [0.069, 0.055, 0.054],
- [0.102, 0.041, 0.042],
- [0.364, 0.261, 0.253],
- [0.052, 0.023, 0.022],
- [0.043, 0.018, 0.018],
- [0.037, 0.023, 0.023]
+ [0.008, 0.008, 0.003],
+ [0.177, 0.05, 0.034],
+ [0.534, 0.236, 0.203],
+ [0.786, 0.359, 0.306],
+ [3.849, 3.457, 3.101],
+ [5.609, 5.009, 5.166],
+ [0.092, 0.079, 0.056],
+ [0.131, 0.069, 0.045],
+ [5.134, 4.057, 4.234],
+ [5.696, 3.635, 3.293],
+ [0.967, 0.617, 0.694],
+ [1.042, 0.753, 0.75],
+ [4.347, 3.492, 3.38],
+ [9.399, 8.841, 9.434],
+ [7.281, 6.927, 7.012],
+ [2.971, 1.747, 1.741],
+ [16.99, 17.038, 16.948],
+ [12.636, 11.791, 12.76],
+ [34.829, 33.806, 33.724],
+ [0.418, 0.003, 0.003],
+ [11.583, 3.11, 2.968],
+ [13.232, 0.904, 1.011],
+ [13.426, 5.426, 5.37],
+ [6.793, 2.226, 2.2],
+ [2.629, 1.268, 1.245],
+ [1.411, 1.035, 1.24],
+ [1.912, 0.98, 0.993],
+ [8.512, 3.834, 3.492],
+ [42.807, 41.532, 42.304],
+ [0.231, 0.109, 0.109],
+ [2.412, 1.992, 1.759],
+ [4.792, 3.403, 3.584],
+ [29.243, 28.747, 29.02],
+ [26.688, 26.654, 26.561],
+ [26.792, 26.667, 27.232],
+ [1.455, 0.988, 0.981],
+ [0.189, 0.133, 0.135],
+ [0.072, 0.056, 0.057],
+ [0.106, 0.049, 0.045],
+ [0.384, 0.245, 0.274],
+ [0.054, 0.022, 0.022],
+ [0.044, 0.019, 0.019],
+ [0.035, 0.018, 0.023]
]
}
diff --git a/clickhouse/results/c6a.metal.json b/clickhouse/results/c6a.metal.json
index 0afaf2db1..b53a97954 100644
--- a/clickhouse/results/c6a.metal.json
+++ b/clickhouse/results/c6a.metal.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
"load_time": 7,
- "data_size": 14467556065,
+ "data_size": 14464530126,
"result": [
- [0.003, 0.002, 0.002],
- [0.02, 0.011, 0.01],
- [0.042, 0.012, 0.013],
- [0.092, 0.014, 0.015],
- [0.79, 0.173, 0.168],
- [0.91, 0.167, 0.168],
- [0.014, 0.01, 0.009],
- [0.016, 0.012, 0.011],
- [0.389, 0.288, 0.294],
- [0.593, 0.295, 0.301],
- [0.17, 0.091, 0.093],
- [0.173, 0.097, 0.094],
- [0.818, 0.139, 0.129],
- [1.573, 0.185, 0.182],
- [0.778, 0.159, 0.144],
- [0.158, 0.085, 0.086],
- [1.804, 0.315, 0.284],
- [1.203, 0.229, 0.208],
- [3.047, 0.56, 0.515],
- [0.121, 0.006, 0.006],
- [8.624, 0.077, 0.085],
- [10.011, 0.05, 0.046],
- [12.342, 0.127, 0.136],
- [6.2, 0.556, 0.559],
- [1.771, 0.047, 0.045],
- [0.876, 0.04, 0.034],
- [2.4, 0.047, 0.045],
- [9.066, 0.191, 0.176],
- [7.162, 0.856, 0.854],
- [0.048, 0.03, 0.032],
- [1.306, 0.127, 0.126],
- [4.653, 0.162, 0.182],
- [3.439, 0.866, 0.671],
- [8.771, 0.641, 0.61],
- [8.745, 0.604, 0.597],
- [0.09, 0.064, 0.064],
- [0.091, 0.054, 0.054],
- [0.04, 0.031, 0.037],
- [0.052, 0.025, 0.022],
- [0.153, 0.099, 0.108],
- [0.03, 0.016, 0.019],
- [0.03, 0.013, 0.014],
- [0.023, 0.012, 0.013]
+ [0.004, 0.002, 0.002],
+ [0.021, 0.011, 0.01],
+ [0.039, 0.014, 0.013],
+ [0.086, 0.014, 0.014],
+ [0.369, 0.175, 0.171],
+ [0.805, 0.179, 0.165],
+ [0.017, 0.011, 0.01],
+ [0.018, 0.012, 0.013],
+ [0.369, 0.301, 0.291],
+ [0.636, 0.313, 0.311],
+ [0.172, 0.104, 0.089],
+ [0.151, 0.092, 0.077],
+ [0.965, 0.16, 0.147],
+ [1.581, 0.216, 0.205],
+ [0.788, 0.153, 0.156],
+ [0.189, 0.089, 0.085],
+ [1.918, 0.343, 0.335],
+ [1.238, 0.235, 0.23],
+ [3.243, 0.589, 0.597],
+ [0.062, 0.003, 0.003],
+ [8.793, 0.074, 0.078],
+ [10.239, 0.049, 0.045],
+ [12.631, 0.122, 0.121],
+ [6.63, 0.167, 0.17],
+ [1.933, 0.043, 0.044],
+ [0.937, 0.043, 0.039],
+ [2.444, 0.052, 0.042],
+ [9.192, 0.106, 0.108],
+ [7.488, 0.979, 0.914],
+ [0.048, 0.034, 0.033],
+ [1.368, 0.101, 0.103],
+ [4.792, 0.144, 0.127],
+ [3.628, 0.864, 0.729],
+ [8.935, 0.668, 0.644],
+ [8.975, 0.659, 0.657],
+ [0.092, 0.068, 0.06],
+ [0.05, 0.032, 0.034],
+ [0.03, 0.028, 0.021],
+ [0.031, 0.017, 0.018],
+ [0.075, 0.054, 0.052],
+ [0.025, 0.017, 0.018],
+ [0.021, 0.013, 0.011],
+ [0.019, 0.01, 0.011]
]
}
diff --git a/clickhouse/results/c6a.xlarge.json b/clickhouse/results/c6a.xlarge.json
index f43d0735f..02d967355 100644
--- a/clickhouse/results/c6a.xlarge.json
+++ b/clickhouse/results/c6a.xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 310,
- "data_size": 14441474487,
+ "load_time": 322,
+ "data_size": 14440704594,
"result": [
- [0.002, 0.003, 0.002],
- [0.071, 0.014, 0.02],
- [0.204, 0.089, 0.087],
- [1.073, 0.13, 0.128],
- [1.523, 1.136, 1.179],
- [2.355, 1.733, 1.716],
- [0.054, 0.025, 0.025],
- [0.055, 0.026, 0.021],
- [1.861, 1.433, 1.4],
- [2.119, 1.708, 1.832],
- [0.696, 0.326, 0.337],
- [1.092, 0.374, 0.344],
- [1.914, 1.484, 1.498],
- [2.776, 2.33, 2.301],
- [2.092, 1.623, 1.62],
- [1.158, 0.878, 0.888],
- [5.383, 7.304, 7.322],
- [3.266, 5.266, 5.321],
- [16.934, 15.594, 15.957],
- [0.235, 0.007, 0.006],
- [10.347, 0.919, 0.912],
- [11.44, 0.194, 0.19],
- [13.757, 1.16, 1.178],
- [7.275, 1.779, 1.775],
- [2.682, 0.557, 0.557],
- [0.798, 0.48, 0.459],
- [2.325, 0.59, 0.562],
- [9.702, 2.003, 1.867],
- [25.301, 22.542, 22.46],
- [0.123, 0.069, 0.074],
- [1.765, 1.226, 1.21],
- [5.291, 1.543, 1.502],
- [19.027, 17.658, 18.594],
- [20.047, 17.334, 18.749],
- [16.336, 13.707, 14.309],
- [0.85, 0.581, 0.586],
- [0.119, 0.077, 0.083],
- [0.047, 0.037, 0.037],
- [0.066, 0.027, 0.028],
- [0.214, 0.15, 0.154],
- [0.034, 0.017, 0.016],
- [0.03, 0.013, 0.013],
- [0.024, 0.014, 0.014]
+ [0.002, 0.002, 0.002],
+ [0.044, 0.015, 0.016],
+ [0.29, 0.087, 0.091],
+ [1.08, 0.13, 0.131],
+ [1.466, 1.128, 1.101],
+ [2.317, 1.819, 1.884],
+ [0.044, 0.027, 0.03],
+ [0.05, 0.021, 0.022],
+ [1.756, 1.437, 1.473],
+ [2.099, 1.676, 1.734],
+ [1.103, 0.288, 0.303],
+ [0.819, 0.353, 0.349],
+ [1.875, 1.49, 1.447],
+ [2.568, 2.229, 2.17],
+ [1.837, 1.566, 1.728],
+ [1.153, 0.877, 0.875],
+ [7.631, 7.234, 7.312],
+ [5.709, 5.309, 5.169],
+ [14.909, 14.722, 15.133],
+ [0.204, 0.003, 0.003],
+ [10.232, 0.746, 0.729],
+ [11.481, 0.185, 0.186],
+ [13.76, 1.177, 1.153],
+ [7.241, 1.011, 0.992],
+ [2.71, 0.57, 0.555],
+ [0.802, 0.461, 0.46],
+ [2.368, 0.564, 0.572],
+ [9.449, 1.417, 1.485],
+ [24.501, 22.652, 23.138],
+ [0.111, 0.073, 0.073],
+ [1.816, 1.058, 1.078],
+ [5.306, 1.36, 1.323],
+ [18.891, 17.634, 18.129],
+ [19.264, 18.928, 17.726],
+ [16.022, 13.52, 13.845],
+ [0.834, 0.574, 0.604],
+ [0.109, 0.093, 0.092],
+ [0.05, 0.036, 0.034],
+ [0.059, 0.027, 0.025],
+ [0.192, 0.137, 0.13],
+ [0.039, 0.015, 0.016],
+ [0.034, 0.016, 0.013],
+ [0.025, 0.014, 0.013]
]
}
diff --git a/clickhouse/results/c7a.metal-48xl.json b/clickhouse/results/c7a.metal-48xl.json
index 93dc992c7..ea89f1d58 100644
--- a/clickhouse/results/c7a.metal-48xl.json
+++ b/clickhouse/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse",
- "date": "2025-08-30",
+ "system": "ClickHouse",
+ "date": "2025-10-09",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","ClickHouse derivative"],
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","ClickHouse derivative"],
"load_time": 5,
- "data_size": 14462768490,
+ "data_size": 14463377533,
"result": [
- [0.002, 0.001, 0.002],
- [0.024, 0.012, 0.01],
- [0.045, 0.013, 0.012],
- [0.156, 0.012, 0.011],
- [0.906, 0.315, 0.324],
- [0.972, 0.327, 0.322],
- [0.014, 0.01, 0.01],
- [0.019, 0.014, 0.014],
- [0.473, 0.266, 0.27],
- [0.984, 0.281, 0.283],
- [0.257, 0.089, 0.091],
- [0.675, 0.1, 0.099],
- [1.137, 0.089, 0.088],
- [1.95, 0.123, 0.122],
- [1.22, 0.097, 0.082],
- [0.543, 0.052, 0.054],
- [2.008, 0.135, 0.135],
- [1.787, 0.109, 0.107],
- [3.46, 0.263, 0.246],
- [0.07, 0.005, 0.005],
- [9.238, 0.061, 0.058],
- [10.517, 0.043, 0.041],
- [12.755, 0.093, 0.084],
- [6.777, 0.61, 0.594],
- [1.825, 0.036, 0.032],
- [1.171, 0.029, 0.026],
- [2.634, 0.033, 0.033],
- [9.423, 0.114, 0.102],
- [7.752, 0.47, 0.466],
- [0.096, 0.038, 0.04],
- [1.437, 0.104, 0.083],
- [5.006, 0.106, 0.104],
- [3.859, 0.311, 0.303],
- [8.991, 0.314, 0.3],
- [9.027, 0.312, 0.308],
- [0.117, 0.045, 0.044],
- [0.101, 0.026, 0.024],
- [0.042, 0.025, 0.021],
- [0.069, 0.016, 0.015],
- [0.203, 0.129, 0.118],
- [0.038, 0.015, 0.015],
- [0.035, 0.013, 0.012],
- [0.025, 0.01, 0.012]
+ [0.002, 0.002, 0.001],
+ [0.021, 0.011, 0.011],
+ [0.034, 0.013, 0.013],
+ [0.316, 0.012, 0.012],
+ [1.028, 0.325, 0.334],
+ [1.192, 0.343, 0.335],
+ [0.016, 0.011, 0.012],
+ [0.02, 0.015, 0.015],
+ [0.718, 0.279, 0.279],
+ [1.228, 0.288, 0.293],
+ [0.457, 0.117, 0.119],
+ [0.733, 0.093, 0.092],
+ [1.188, 0.092, 0.087],
+ [2.053, 0.136, 0.13],
+ [1.265, 0.084, 0.082],
+ [0.641, 0.057, 0.056],
+ [2.056, 0.154, 0.143],
+ [1.919, 0.117, 0.115],
+ [3.635, 0.267, 0.257],
+ [0.053, 0.003, 0.002],
+ [9.533, 0.062, 0.057],
+ [10.626, 0.043, 0.041],
+ [13.057, 0.099, 0.084],
+ [7.249, 0.137, 0.126],
+ [2.588, 0.031, 0.035],
+ [1.134, 0.027, 0.024],
+ [2.664, 0.031, 0.034],
+ [9.453, 0.083, 0.077],
+ [7.882, 0.485, 0.487],
+ [0.057, 0.041, 0.041],
+ [1.819, 0.069, 0.069],
+ [5.13, 0.084, 0.095],
+ [3.99, 0.317, 0.313],
+ [9.32, 0.372, 0.338],
+ [9.27, 0.351, 0.336],
+ [0.077, 0.047, 0.054],
+ [0.069, 0.046, 0.046],
+ [0.037, 0.027, 0.033],
+ [0.044, 0.024, 0.022],
+ [0.125, 0.103, 0.108],
+ [0.031, 0.022, 0.018],
+ [0.028, 0.018, 0.016],
+ [0.023, 0.013, 0.012]
]
}
+
diff --git a/clickhouse/results/c8g.4xlarge.json b/clickhouse/results/c8g.4xlarge.json
index e80d819af..ad995f06b 100644
--- a/clickhouse/results/c8g.4xlarge.json
+++ b/clickhouse/results/c8g.4xlarge.json
@@ -1,57 +1,57 @@
{
"system": "ClickHouse",
- "date": "2025-08-31",
+ "date": "2025-10-09",
"machine": "c8g.4xlarge",
"cluster_size": 1,
"proprietary": "no",
"tuned": "no",
"tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 224,
- "data_size": 14465212977,
+ "load_time": 220,
+ "data_size": 14465849263,
"result": [
- [0.001, 0.001, 0.001],
- [0.023, 0.005, 0.005],
- [0.098, 0.015, 0.017],
- [0.738, 0.025, 0.025],
- [0.77, 0.161, 0.153],
- [1.011, 0.262, 0.261],
- [0.018, 0.008, 0.008],
- [0.017, 0.007, 0.007],
- [0.521, 0.252, 0.219],
- [0.993, 0.294, 0.281],
- [0.34, 0.09, 0.093],
- [0.676, 0.1, 0.101],
- [1.186, 0.244, 0.254],
- [1.767, 0.361, 0.355],
- [0.941, 0.288, 0.281],
- [0.368, 0.15, 0.152],
- [2.133, 0.657, 0.651],
- [1.433, 0.405, 0.41],
- [3.568, 1.216, 1.203],
- [0.062, 0.003, 0.003],
- [9.412, 0.198, 0.188],
- [10.76, 0.059, 0.056],
- [12.97, 0.255, 0.261],
- [6.962, 0.881, 0.879],
- [2.38, 0.106, 0.106],
- [1.171, 0.084, 0.086],
- [2.617, 0.106, 0.108],
- [9.477, 0.353, 0.369],
- [7.885, 2.8, 2.784],
- [0.043, 0.024, 0.024],
- [2.191, 0.24, 0.229],
- [4.932, 0.28, 0.262],
- [4.099, 1.072, 1.062],
- [9.573, 1.25, 1.21],
- [9.696, 1.252, 1.221],
- [0.231, 0.117, 0.129],
- [0.04, 0.024, 0.024],
- [0.031, 0.017, 0.017],
- [0.036, 0.013, 0.013],
- [0.066, 0.038, 0.038],
- [0.027, 0.01, 0.01],
- [0.023, 0.008, 0.008],
- [0.019, 0.007, 0.007]
+ [0.003, 0.001, 0.001],
+ [0.086, 0.006, 0.005],
+ [0.068, 0.015, 0.017],
+ [0.654, 0.025, 0.026],
+ [0.709, 0.158, 0.156],
+ [1.108, 0.27, 0.272],
+ [0.013, 0.008, 0.008],
+ [0.014, 0.007, 0.008],
+ [0.538, 0.224, 0.23],
+ [1.019, 0.265, 0.269],
+ [0.381, 0.093, 0.097],
+ [0.72, 0.101, 0.103],
+ [1.211, 0.251, 0.236],
+ [1.823, 0.362, 0.371],
+ [0.972, 0.266, 0.272],
+ [0.401, 0.15, 0.148],
+ [2.162, 0.674, 0.663],
+ [1.38, 0.417, 0.416],
+ [3.531, 1.214, 1.198],
+ [0.079, 0.002, 0.002],
+ [9.502, 0.205, 0.192],
+ [10.765, 0.06, 0.062],
+ [12.972, 0.253, 0.251],
+ [6.707, 0.297, 0.302],
+ [2.371, 0.106, 0.106],
+ [1.208, 0.087, 0.086],
+ [2.629, 0.106, 0.106],
+ [9.559, 0.264, 0.262],
+ [8.099, 2.872, 2.828],
+ [0.052, 0.025, 0.025],
+ [2.21, 0.197, 0.196],
+ [5.009, 0.235, 0.23],
+ [4.176, 1.108, 1.082],
+ [9.577, 1.213, 1.19],
+ [9.586, 1.22, 1.176],
+ [0.199, 0.132, 0.133],
+ [0.077, 0.052, 0.052],
+ [0.038, 0.03, 0.029],
+ [0.046, 0.024, 0.024],
+ [0.143, 0.085, 0.085],
+ [0.038, 0.015, 0.015],
+ [0.036, 0.012, 0.012],
+ [0.026, 0.011, 0.011]
]
}
diff --git a/clickhouse/results/c8g.metal-48xl.json b/clickhouse/results/c8g.metal-48xl.json
index 9aad5c8ca..172bec61a 100644
--- a/clickhouse/results/c8g.metal-48xl.json
+++ b/clickhouse/results/c8g.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "ClickHouse",
- "date": "2025-08-30",
+ "system": "ClickHouse",
+ "date": "2025-10-09",
"machine": "c8g.metal-48xl",
"cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["C++","column-oriented","ClickHouse derivative"],
- "load_time": 5,
- "data_size": 14460771204,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["C++","column-oriented","ClickHouse derivative"],
+ "load_time": 6,
+ "data_size": 14453239588,
"result": [
- [0.002, 0.001, 0.001],
- [0.018, 0.01, 0.009],
- [0.042, 0.01, 0.01],
- [0.549, 0.011, 0.011],
- [0.964, 0.267, 0.255],
- [1.19, 0.259, 0.257],
- [0.012, 0.01, 0.009],
- [0.018, 0.013, 0.014],
- [0.769, 0.196, 0.188],
- [1.211, 0.207, 0.203],
- [0.567, 0.072, 0.071],
- [0.79, 0.076, 0.079],
- [1.22, 0.075, 0.072],
- [2.066, 0.105, 0.096],
- [1.306, 0.075, 0.071],
- [0.63, 0.045, 0.042],
- [2.114, 0.141, 0.141],
- [1.915, 0.119, 0.109],
- [3.581, 0.242, 0.235],
- [0.094, 0.005, 0.005],
- [9.666, 0.074, 0.075],
- [10.704, 0.032, 0.033],
- [12.991, 0.097, 0.093],
- [7.003, 0.608, 0.621],
- [2.276, 0.033, 0.034],
- [1.239, 0.025, 0.024],
- [2.689, 0.033, 0.033],
- [9.505, 0.122, 0.114],
- [7.925, 0.457, 0.461],
- [0.081, 0.057, 0.056],
- [1.83, 0.066, 0.065],
- [5.094, 0.084, 0.08],
- [3.489, 0.272, 0.266],
- [8.68, 0.298, 0.29],
- [8.692, 0.301, 0.288],
- [0.087, 0.034, 0.036],
- [0.04, 0.025, 0.024],
- [0.027, 0.018, 0.021],
- [0.034, 0.017, 0.017],
- [0.066, 0.038, 0.042],
- [0.024, 0.013, 0.013],
- [0.021, 0.011, 0.012],
- [0.019, 0.011, 0.01]
+ [0.003, 0.002, 0.001],
+ [0.022, 0.012, 0.011],
+ [0.06, 0.012, 0.012],
+ [0.205, 0.012, 0.011],
+ [0.947, 0.249, 0.255],
+ [1.077, 0.27, 0.271],
+ [0.016, 0.01, 0.009],
+ [0.022, 0.016, 0.016],
+ [0.599, 0.199, 0.203],
+ [1.102, 0.209, 0.209],
+ [0.5, 0.079, 0.083],
+ [0.693, 0.066, 0.07],
+ [1.224, 0.074, 0.073],
+ [2.025, 0.1, 0.099],
+ [1.289, 0.072, 0.07],
+ [0.589, 0.046, 0.043],
+ [2.101, 0.14, 0.14],
+ [1.871, 0.121, 0.114],
+ [3.395, 0.238, 0.239],
+ [0.089, 0.003, 0.002],
+ [8.698, 0.075, 0.075],
+ [10.16, 0.039, 0.036],
+ [12.629, 0.093, 0.09],
+ [6.742, 0.163, 0.166],
+ [1.867, 0.031, 0.03],
+ [0.958, 0.027, 0.026],
+ [2.442, 0.029, 0.029],
+ [9.118, 0.074, 0.071],
+ [7.439, 0.483, 0.482],
+ [0.086, 0.059, 0.058],
+ [1.276, 0.055, 0.056],
+ [4.775, 0.071, 0.069],
+ [3.552, 0.278, 0.261],
+ [8.67, 0.309, 0.293],
+ [8.669, 0.305, 0.303],
+ [0.087, 0.036, 0.035],
+ [0.081, 0.051, 0.055],
+ [0.048, 0.03, 0.029],
+ [0.064, 0.026, 0.025],
+ [0.142, 0.085, 0.095],
+ [0.041, 0.017, 0.019],
+ [0.036, 0.015, 0.014],
+ [0.03, 0.012, 0.012]
]
}
+
diff --git a/cloud-init.sh.in b/cloud-init.sh.in
index 1a7479cd9..32b33c381 100644
--- a/cloud-init.sh.in
+++ b/cloud-init.sh.in
@@ -6,7 +6,7 @@ export DEBIAN_FRONTEND=noninteractive
apt-get update -y
apt-get install -y wget curl git jq
-git clone --depth 1 https://github.com/ClickHouse/ClickBench.git
+git clone --depth 1 'https://github.com/@repo@.git' --branch '@branch@' ClickBench
cd ClickBench/@system@
# The log will be sent to ClickHouse and processed then by materialized views:
diff --git a/data.generated.js b/data.generated.js
index 73fee48ab..cbdb45ca0 100644
--- a/data.generated.js
+++ b/data.generated.js
@@ -2,6 +2,12 @@ const data = [
{"system":"AlloyDB","date":"2023-11-25","machine":"AlloyDB: 16 vCPU 128 GB","cluster_size":"serverless","comment":"","proprietary":"yes","tuned":"no","tags":["C","column-oriented","PostgreSQL compatible","managed","gcp"],"load_time":0,"data_size":9941379875,"result":[[3.589,3.579,3.546],[0.086,0.083,0.085],[3.108,2.977,2.998],[2.446,2.369,2.397],[41.171,39.897,41.067],[133.678,131.099,128.083],[4.127,4.023,4.080],[0.096,0.093,0.095],[36.865,35.327,35.255],[48.457,47.931,46.521],[2.973,2.891,2.953],[2.725,2.635,2.694],[23.608,23.603,23.461],[33.287,32.037,31.814],[12.956,12.473,12.339],[21.373,21.359,21.199],[46.848,46.703,46.106],[0.067,0.066,0.066],[49.553,49.131,48.820],[0.060,0.057,0.059],[7.331,7.223,7.313],[7.307,7.032,7.220],[2.552,2.538,2.477],[1.208,1.166,1.199],[0.760,0.732,0.754],[6.913,6.748,6.646],[1.028,1.021,0.985],[6.671,6.461,6.445],[73.945,71.686,73.741],[0.006,0.006,0.006],[11.499,11.354,10.951],[23.934,23.638,22.781],[204.595,195.917,203.924],[198.938,190.582,191.488],[197.077,193.706,190.226],[21.823,21.722,21.082],[0.576,0.553,0.575],[0.151,0.147,0.148],[0.105,0.104,0.101],[61.084,59.116,60.052],[0.154,0.152,0.153],[0.106,0.106,0.104],[0.063,0.063,0.061]],"source":"alloydb/results/gcp.128GB_tuned.json"}
,{"system":"AlloyDB","date":"2023-11-25","machine":"AlloyDB: 8 vCPU 64 GB","cluster_size":"serverless","proprietary":"yes","tuned":"no","comment":"","tags":["C","column-oriented","PostgreSQL compatible","managed","gcp"],"load_time":1542.701,"data_size":9941379875,"result":[[0.044,0.045,0.044],[0.054,0.057,0.053],[5.522,5.553,5.538],[0.181,0.171,0.171],[38.255,38.157,38.574],[132.301,124.598,129.700],[0.153,0.148,0.150],[0.058,0.056,0.057],[48.850,54.456,47.637],[58.382,50.892,53.646],[4.423,3.713,3.759],[5.696,4.672,4.482],[32.470,28.543,37.199],[36.837,34.047,34.808],[33.214,30.918,30.533],[41.696,33.773,36.766],[43.206,37.413,37.309],[25.460,23.551,23.502],[83.605,72.146,72.803],[0.037,0.037,0.037],[1.846,1.837,1.826],[1.845,1.846,1.832],[2.800,2.803,2.799],[1.847,1.853,2.098],[0.247,0.249,0.247],[0.242,0.241,0.248],[0.257,0.257,0.257],[12.250,13.874,13.809],[140.767,137.803,135.557],[34.618,32.687,32.997],[11.949,10.602,10.636],[17.551,15.420,15.802],[136.567,132.208,128.123],[299.996,299.397,300.196],[292.537,294.086,290.848],[35.031,35.992,34.834],[1.773,1.774,1.772],[0.208,0.209,0.208],[0.081,0.081,0.080],[79.639,79.522,79.742],[0.167,0.165,0.166],[0.088,0.088,0.088],[0.268,0.276,0.265]],"source":"alloydb/results/gcp.64GB.json"}
,{"system":"AlloyDB (tuned)","date":"2023-11-25","machine":"AlloyDB: 8 vCPU 64 GB","cluster_size":"serverless","proprietary":"yes","tuned":"yes","comment":"","tags":["C","column-oriented","PostgreSQL compatible","managed","gcp"],"load_time":0,"data_size":9941379875,"result":[[7.110,6.811,6.854],[0.107,0.105,0.102],[6.421,6.420,6.171],[7.888,7.651,7.839],[47.474,46.462,46.613],[151.574,151.010,147.708],[8.208,8.059,7.984],[0.126,0.122,0.125],[50.911,50.117,48.580],[65.249,62.631,63.581],[3.484,3.463,3.371],[3.437,3.358,3.289],[30.446,29.722,29.293],[46.184,44.271,44.868],[17.842,17.052,17.216],[39.271,39.059,38.043],[61.953,60.639,60.360],[40.387,39.676,39.632],[117.091,113.773,113.700],[0.071,0.069,0.068],[28.628,28.238,28.545],[7.469,7.297,7.455],[11.979,11.491,11.958],[2.061,2.046,1.969],[1.494,1.427,1.492],[7.039,6.814,6.820],[1.700,1.644,1.621],[16.295,15.774,15.909],[143.972,143.475,137.006],[34.647,33.733,32.987],[12.950,12.886,12.758],[21.142,20.326,20.558],[182.456,182.135,174.993],[280.354,280.261,270.723],[283.267,280.281,283.257],[39.548,38.026,38.049],[3.282,3.122,3.166],[0.436,0.422,0.417],[0.109,0.109,0.109],[99.913,96.761,97.573],[0.181,0.177,0.176],[0.111,0.111,0.111],[0.094,0.090,0.093]],"source":"alloydb/results/gcp.64GB_tuned.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.136,0.096,0.074],[0.127,0.112,0.111],[0.181,0.151,0.177],[0.223,0.151,0.144],[0.589,0.562,0.562],[1.029,0.928,0.943],[0.243,0.133,0.145],[0.23,0.133,0.129],[1.254,0.778,0.732],[0.951,0.931,0.944],[0.297,0.282,0.299],[0.331,0.346,0.32],[0.945,0.912,0.901],[1.352,1.338,1.325],[1.027,1.006,0.976],[0.625,0.636,0.636],[1.72,1.688,1.691],[1.338,1.326,1.405],[6.22,6.124,6.129],[0.099,0.162,0.099],[8.68,1.757,1.758],[1.608,1.6,1.598],[7.857,3.193,3.232],[0.892,0.783,0.762],[0.293,0.302,0.306],[0.578,0.565,0.57],[0.25,0.25,0.25],[1.926,1.925,1.916],[17.739,17.519,17.484],[0.157,0.151,0.246],[1.29,1.065,1.058],[2.691,1.231,1.206],[3.488,4.231,3.888],[3.697,3.675,3.615],[3.713,3.683,3.755],[1.268,1.024,0.974],[0.201,0.197,0.224],[0.223,0.196,0.19],[0.146,0.148,0.155],[0.367,0.318,0.305],[0.129,0.148,0.116],[0.117,0.12,0.118],[0.29,0.282,0.269]],"source":"arc/results/c6a.2xlarge.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.349,0.098,0.072],[0.206,0.085,0.09],[0.143,0.108,0.111],[0.115,0.119,0.126],[0.434,0.372,0.374],[0.614,0.576,0.57],[0.152,0.098,0.093],[0.16,0.101,0.104],[0.514,0.487,0.489],[0.607,0.587,0.588],[0.178,0.174,0.19],[0.205,0.209,0.213],[0.612,0.59,0.581],[0.946,0.915,0.907],[0.618,0.635,0.638],[0.503,0.464,0.46],[1.124,1.047,1.032],[0.804,0.908,0.851],[3.389,3.337,3.387],[0.096,0.099,0.097],[1.06,0.951,0.949],[0.872,0.882,0.873],[1.692,1.717,1.702],[0.532,0.551,0.562],[0.225,0.231,0.234],[0.339,0.33,0.327],[0.177,0.168,0.176],[1.033,1.035,1.03],[9.031,9.109,9.118],[0.118,0.112,0.113],[0.965,0.631,0.615],[0.728,0.726,0.752],[2.114,1.981,1.969],[2.349,2.352,2.355],[2.422,2.382,2.417],[0.626,0.819,0.578],[0.175,0.2,0.192],[0.16,0.164,0.172],[0.149,0.142,0.147],[0.339,0.309,0.311],[0.103,0.108,0.098],[0.095,0.1,0.093],[0.256,0.266,0.257]],"source":"arc/results/c6a.4xlarge.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.131,0.072,0.073],[0.14,0.146,0.117],[0.118,0.14,0.11],[0.113,0.148,0.123],[0.383,0.543,0.501],[0.448,0.437,0.32],[0.1,0.095,0.099],[0.136,0.113,0.129],[0.242,0.459,0.387],[0.662,0.351,0.35],[0.146,0.14,0.158],[0.141,0.155,0.149],[0.469,0.278,0.308],[0.561,0.385,0.63],[0.331,0.329,0.533],[0.587,0.474,0.627],[0.787,0.932,0.409],[0.614,0.583,0.754],[0.84,1.072,1.384],[0.19,0.111,0.122],[0.29,0.292,0.306],[0.27,0.336,0.294],[0.556,0.47,0.481],[0.606,0.82,0.504],[0.245,0.273,0.23],[0.161,0.181,0.194],[0.162,0.171,0.158],[0.348,0.344,0.55],[2.828,3.088,4.168],[0.296,0.288,0.293],[0.383,0.686,0.258],[0.326,0.422,1.264],[1.532,1.343,1.475],[0.886,1.171,1.252],[0.749,0.771,1.104],[0.333,0.832,0.429],[0.344,0.361,0.261],[0.273,0.259,0.273],[0.317,0.251,0.231],[0.304,0.312,0.312],[0.101,0.11,0.125],[0.126,0.131,0.125],[0.272,0.304,0.331]],"source":"arc/results/c6a.metal.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.137,0.079,0.134],[0.124,0.111,0.127],[0.108,0.116,0.124],[0.155,0.131,0.12],[0.581,0.437,0.466],[0.455,0.426,0.258],[0.116,0.132,0.092],[0.09,0.089,0.089],[0.419,0.602,0.527],[0.683,0.73,0.591],[0.124,0.129,0.137],[0.133,0.131,0.131],[0.329,0.261,0.236],[0.352,0.818,0.585],[0.597,0.721,0.657],[0.295,0.306,0.322],[0.608,0.632,0.521],[0.6,0.686,0.704],[0.955,0.849,0.958],[0.138,0.094,0.103],[0.278,0.268,0.258],[0.227,0.244,0.458],[0.945,0.366,0.346],[0.547,0.508,0.467],[0.2,0.203,0.204],[0.17,0.155,0.296],[0.136,0.147,0.18],[0.58,0.29,0.279],[2.904,2.706,3.408],[0.133,0.126,0.104],[0.768,0.612,0.672],[1.023,0.945,1.163],[1.301,1.34,1.128],[1.418,1.362,1.294],[1.205,1.156,1.111],[0.171,0.188,0.688],[0.174,0.188,0.185],[0.161,0.16,0.149],[0.126,0.131,0.128],[0.284,0.304,0.289],[0.096,0.122,0.138],[0.123,0.112,0.116],[0.242,0.252,0.236]],"source":"arc/results/c7a.metal-48xl.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.536,0.089,0.087],[0.138,0.081,0.08],[0.139,0.098,0.099],[0.116,0.102,0.097],[0.321,0.25,0.236],[0.372,0.364,0.366],[0.128,0.09,0.086],[0.152,0.088,0.084],[0.357,0.302,0.296],[0.376,0.379,0.378],[0.142,0.136,0.134],[0.158,0.162,0.163],[0.388,0.383,0.376],[0.569,0.54,0.536],[0.389,0.394,0.415],[0.322,0.27,0.273],[0.634,0.605,0.602],[0.523,0.534,0.538],[1.77,1.643,1.67],[0.102,0.096,0.083],[0.794,0.735,0.732],[0.66,0.662,0.659],[1.21,1.195,1.176],[0.472,0.479,0.469],[0.186,0.185,0.188],[0.229,0.226,0.229],[0.142,0.139,0.138],[0.774,0.775,0.772],[5.37,5.366,5.386],[0.11,0.11,0.111],[0.425,0.421,0.415],[0.478,0.447,0.441],[1.076,0.99,0.968],[1.328,1.318,1.34],[1.368,1.356,1.345],[0.331,0.369,0.452],[0.196,0.183,0.178],[0.16,0.16,0.158],[0.138,0.137,0.138],[0.302,0.28,0.271],[0.1,0.102,0.103],[0.1,0.099,0.102],[0.213,0.212,0.214]],"source":"arc/results/c8g.4xlarge.json"}
+,{"system":"Arc","date":"2025-10-16","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Python","column-oriented","time-series"],"load_time":0,"data_size":14779976446,"result":[[0.071,0.071,0.06],[0.075,0.074,0.066],[0.083,0.075,0.072],[0.081,0.103,0.083],[0.262,0.326,0.276],[0.282,0.281,0.344],[0.075,0.075,0.074],[0.074,0.072,0.075],[0.15,0.252,0.282],[0.346,0.399,0.413],[0.195,0.158,0.114],[0.103,0.098,0.093],[0.228,0.259,0.213],[0.311,0.571,0.531],[0.236,0.251,0.214],[0.152,0.145,0.162],[0.341,0.272,0.335],[0.45,0.368,0.608],[0.635,0.56,0.883],[0.078,0.07,0.099],[0.241,0.249,0.232],[0.196,0.271,0.197],[0.311,0.29,0.289],[0.443,0.457,0.436],[0.171,0.152,0.162],[0.113,0.128,0.142],[0.121,0.107,0.113],[0.26,0.25,0.251],[1.797,2.571,2.542],[0.166,0.14,0.102],[0.204,0.191,0.229],[0.23,0.244,0.232],[0.805,0.552,0.69],[0.541,0.534,0.571],[0.696,0.582,0.567],[0.153,0.163,0.26],[0.171,0.167,0.165],[0.142,0.14,0.141],[0.114,0.116,0.112],[0.257,0.256,0.262],[0.08,0.089,0.086],[0.078,0.105,0.084],[0.228,0.205,0.209]],"source":"arc/results/c8g.metal-48xl.json"}
,{"system":"Athena (partitioned)","date":"2022-07-01","machine":"serverless","cluster_size":"serverless","proprietary":"yes","tuned":"no","comment":"","tags":["stateless","managed","Java","column-oriented","aws"],"load_time":0,"data_size":13800000000,"result":[[2.777,3.275,2.925],[1.503,3.136,4.003],[4.544,3.833,3.64],[3.9,2.514,3.522],[3.46,2.186,3.244],[3.624,2.742,3.185],[2.21,1.984,3.123],[3.207,2.403,2.685],[2.936,2.014,3.869],[8.333,7.102,4.434],[7.401,4.697,3.155],[4.214,3.065,4.748],[6.207,4.213,2.576],[3.428,3.085,3.401],[2.92,3.3,3.278],[2.205,2.558,2.419],[4.641,3.888,2.155],[3.219,2.822,3.292],[3.23,3.579,4.31],[2.288,3.543,3.95],[3.032,2.859,2.807],[3.926,3.247,2.928],[4.477,4.048,4.392],[7.407,6.375,6.123],[2.611,2.872,2.827],[2.566,2.567,3.6],[3.673,3.733,2.925],[2.426,3.218,2.78],[5.125,3.778,4.25],[4.565,4.03,4.066],[3.628,3.219,2.953],[6.207,5.973,3.158],[4.339,5.601,4.234],[2.618,3.107,3.433],[4.661,2.79,2.846],[2.373,1.629,2.734],[2.721,2.15,1.962],[3.207,2.154,2.186],[2.453,2.477,3.217],[2.691,4.732,3.584],[2.589,2.613,3.231],[1.926,3.617,1.82],[1.506,2.404,2.343]],"source":"athena/results/partitioned.json"}
,{"system":"Athena (single)","date":"2022-07-01","machine":"serverless","cluster_size":"serverless","proprietary":"no","tuned":"no","comment":"","tags":["stateless","managed","Java","column-oriented","aws"],"load_time":0,"data_size":13800000000,"result":[[2.268,1.327,2.137],[3.427,2.248,3.605],[3.254,2.548,2.316],[3.025,2.314,3.003],[2.264,2.876,4.213],[3.044,2.745,2.698],[2.732,2.199,2.659],[2.022,3.692,3.072],[2.746,2.477,2.785],[3.53,2.782,4.031],[2.709,2.047,2.853],[2.318,1.969,3.4],[2.635,1.935,2.707],[3.049,3.38,3.071],[3.661,2.387,2.476],[2.479,2.591,2.21],[3.093,3.698,4.351],[3.479,3.236,2.274],[4.36,2.97,3.457],[2.525,2.384,3.328],[3.34,3.174,3.409],[3.163,2.971,3.034],[2.999,3.539,2.906],[6.454,7.597,7.858],[2.754,1.951,2.645],[2.852,3.018,2.718],[2.513,2.678,2.417],[3.293,2.521,2.771],[4.392,3.863,3.981],[3.658,4.246,4.027],[3.028,3.87,2.337],[2.923,3.635,3.591],[3.142,4.105,3.15],[3.66,3.187,4.745],[2.652,2.695,2.742],[2.262,2.776,1.815],[1.881,2.212,2.053],[1.934,2.551,1.524],[2.069,2.26,1.805],[2.626,2.902,2.793],[1.791,2.082,2.481],[3.757,2.6,1.946],[2.608,1.994,3.967]],"source":"athena/results/single.json"}
,{"system":"Aurora for MySQL","date":"2022-07-01","machine":"Aurora: 16acu","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"Some queries cannot run due to ERROR 1114 (HY000) at line 1: The table '/rdsdbdata/tmp/#sqlaff_e5_0' is full","tags":["managed","C++","MySQL compatible","row-oriented","aws"],"load_time":7687.318,"data_size":89614492631,"result":[[740.42,739.91,746.65],[828.2,835.67,832.87],[830.08,830.98,832.38],[829.88,832.83,830.87],[845.99,842.4,843.21],[869.51,870.69,869.75],[823.77,829.08,825.54],[827.74,832.87,829.25],[916.26,909.46,929.17],[946.49,939.27,932.32],[852.37,857.69,854.74],[857.99,864.05,825.14],[null,null,null],[863.37,860.2,865.62],[null,null,null],[891.84,895.28,893.68],[null,null,null],[null,null,null],[1420.12,1419.34,1445.08],[28.94,0.21,0.21],[917.64,917.56,916.92],[923.47,921.7,923.82],[919.95,918.37,920.17],[1002.19,1002.07,1001.2],[902.23,902.65,901.8],[901.17,900.02,898.3],[900.04,898.89,903.35],[901.78,902.71,901.28],[null,null,null],[1153.29,1154,1156.46],[862.57,863.35,859.69],[923.14,921.1,923.92],[1370.78,1401.72,1401.44],[1454.67,1455.55,1458.79],[1463.31,1466.75,1461.83],[941.03,944.07,937.23],[7.42,2.80,2.77],[2.57,2.52,2.59],[1.50,1.52,1.59],[3.62,3.57,3.61],[0.95,0.94,0.94],[0.90,0.92,0.91],[1.69,1.72,1.69]],"source":"aurora-mysql/results/16acu.json"}
@@ -44,110 +50,110 @@ const data = [
,{"system":"Citus","date":"2025-07-11","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C","PostgreSQL compatible","column-oriented"],"load_time":1408,"data_size":18980595583,"result":[[5.204,4.249,4.324],[5.941,3.65,3.595],[9.331,6.808,6.666],[9.219,6.023,5.942],[35.41,31.262,31.331],[105.647,102.098,102.457],[7.458,5.18,5.165],[5.685,3.375,3.377],[64.895,60.362,60.326],[70.488,63.871,63.676],[12.923,8.251,8.179],[14.3,9.443,9.471],[16.802,13.159,13.1],[73.512,66.316,66.715],[18.432,14.512,14.564],[40.204,37.422,37.219],[58.808,53.013,51.577],[30.489,22.499,22.262],[111.376,100.207,100.108],[3.736,1.439,1.392],[30.807,22.704,22.733],[33.842,23.081,23.07],[49.491,30.706,30.662],[168.935,122.11,122.181],[15.793,8.841,8.844],[10.716,6.97,6.946],[15.739,8.859,8.866],[44.741,35.081,35.004],[448.409,440.536,442.036],[56.966,53.879,55.457],[24.868,16.64,16.46],[33.966,20.687,20.842],[111.527,97.786,97.695],[94.171,77.464,76.791],[98.184,81.144,81.126],[44.629,42.639,42.198],[6.434,5.687,5.688],[2.406,1.706,1.681],[1.508,0.713,0.719],[8.522,7.544,7.539],[1.396,0.606,0.609],[1.39,0.584,0.584],[1.417,0.67,0.656]],"source":"citus/results/c6a.4xlarge.json"}
,{"system":"Citus","date":"2025-07-12","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C","PostgreSQL compatible","column-oriented"],"load_time":1714,"data_size":18980595587,"result":[[5.234,4.47,4.429],[5.806,3.758,3.765],[9.312,6.948,7.251],[9.031,6.099,6.138],[35.703,32.613,32.592],[108.523,105.187,105.292],[7.571,5.239,5.217],[5.523,3.429,3.477],[82.151,80.542,80.498],[92.58,87.902,87.818],[12.777,8.31,8.313],[14.184,9.659,9.606],[17.08,13.699,14.024],[74.326,68.906,68.965],[18.649,15.262,15.154],[46.796,44.004,43.868],[75.013,71.031,72.121],[29.077,25.714,26.459],[153.199,147.936,148.412],[3.597,1.483,1.518],[30.862,23.446,23.408],[33.733,23.513,23.532],[49.041,36.635,36.718],[169.664,159.207,160.635],[15.092,8.566,8.584],[10.365,7.097,7.049],[15.596,9.114,9.146],[44.742,35.712,35.678],[483.415,480.681,480.826],[56.805,55.903,54.212],[25.021,17.379,16.973],[34.013,21.23,21.287],[126.52,120.147,121.241],[207.494,203.278,207.22],[219.444,218.355,217.625],[56.147,54.394,54.146],[6.559,5.935,5.898],[2.324,1.715,1.741],[1.374,0.725,0.73],[8.546,7.826,7.826],[1.287,0.618,0.623],[1.252,0.653,0.592],[1.287,0.679,0.664]],"source":"citus/results/c6a.large.json"}
,{"system":"Citus","date":"2025-07-11","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C","PostgreSQL compatible","column-oriented"],"load_time":1596,"data_size":18980595587,"result":[[4.869,4.275,4.366],[5.917,3.715,3.658],[9.524,6.707,6.728],[9.302,6.007,6.003],[35.317,31.369,31.475],[106.249,102.354,102.308],[7.212,5.211,5.183],[5.567,3.374,3.367],[69.822,65.009,64.879],[75.832,67.101,66.84],[12.832,8.198,8.191],[14.391,9.709,9.75],[16.805,13.361,13.498],[73.069,67.086,67.171],[19.51,14.836,14.67],[42.608,38.035,37.543],[60.66,52.853,52.845],[29.978,22.376,22.397],[120.546,110.628,109.065],[3.585,1.508,1.426],[30.775,22.922,22.876],[33.519,23.121,23.117],[49.111,30.908,31.025],[168.659,156.072,156.107],[15.098,8.929,8.432],[10.495,6.995,6.981],[15.457,8.497,8.951],[44.502,35.448,35.28],[450.203,447.223,448.05],[56.174,54.507,53.602],[24.841,16.88,16.794],[33.564,20.993,20.856],[111.408,99.549,99.457],[171.778,170.265,170.464],[183.668,177.821,179.96],[47.188,42.792,43.739],[6.475,5.737,5.708],[2.318,1.706,1.695],[1.381,0.72,0.728],[8.465,7.631,7.614],[1.311,0.62,0.623],[1.336,0.591,0.607],[1.396,0.675,0.659]],"source":"citus/results/c6a.xlarge.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":334.795,"data_size":9942499635,"result":[[0.003,0.024,0.020],[0.062,0.034,0.021],[0.234,0.170,0.160],[0.400,0.361,0.337],[1.914,1.726,1.974],[3.329,2.683,2.452],[0.061,0.052,0.053],[0.033,0.028,0.029],[1.828,1.781,1.672],[3.049,2.626,2.623],[0.703,0.698,0.637],[0.800,0.814,0.785],[2.694,2.521,2.601],[4.691,4.026,3.977],[3.703,3.662,3.734],[1.852,2.019,1.879],[15.654,14.351,14.157],[6.971,10.610,9.950],[25.422,26.567,25.391],[0.067,0.007,0.007],[4.996,2.235,2.127],[5.888,0.531,0.465],[6.307,3.077,2.870],[2.808,2.842,2.700],[1.298,1.352,1.349],[0.913,1.039,0.926],[1.288,1.601,1.358],[4.626,4.510,4.912],[38.966,35.696,36.820],[0.116,0.115,0.115],[1.881,1.840,1.827],[2.328,2.162,2.196],[16.562,15.305,14.940],[15.258,14.973,15.435],[14.502,15.542,15.273],[1.079,1.181,1.113],[0.113,0.102,0.106],[0.074,0.052,0.052],[0.049,0.048,0.046],[0.233,0.196,0.185],[0.030,0.027,0.036],[0.023,0.021,0.024],[0.022,0.020,0.018]],"source":"clickhouse-cloud/results/aws.1.12.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":499.920,"data_size":9944976229,"result":[[0.005,0.002,0.002],[0.058,0.038,0.056],[0.386,0.412,0.552],[0.741,0.717,0.785],[3.780,3.454,3.595],[6.747,6.979,6.573],[0.130,0.115,0.145],[0.054,0.068,0.037],[3.657,3.749,3.720],[4.350,4.739,4.474],[1.079,1.083,1.130],[1.195,1.547,1.402],[4.478,4.313,4.353],[7.481,12.024,7.080],[10.152,6.952,6.598],[3.708,3.825,3.964],[23.340,22.613,22.193],[12.531,10.857,9.773],[27.510,27.315,26.960],[0.088,0.010,0.011],[5.971,2.294,2.421],[6.156,0.523,0.521],[7.282,3.152,3.361],[3.057,2.899,2.864],[1.723,1.516,1.549],[1.053,1.043,1.040],[1.498,1.484,1.515],[5.452,5.169,4.896],[55.000,54.614,54.050],[0.174,0.166,0.179],[2.780,2.775,2.601],[3.380,3.388,3.268],[22.956,21.806,21.953],[23.160,22.610,23.817],[22.732,22.505,21.722],[1.393,1.289,1.159],[0.140,0.150,0.153],[0.068,0.068,0.067],[0.064,0.061,0.065],[0.269,0.271,0.266],[0.035,0.029,0.034],[0.028,0.031,0.027],[0.025,0.022,0.023]],"source":"clickhouse-cloud/results/aws.1.8.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":318.155,"data_size":9946120462,"result":[[0.021,0.013,0.039],[0.102,0.043,0.225],[0.360,0.300,0.287],[0.356,0.422,0.218],[1.055,1.040,1.026],[2.221,2.653,1.866],[0.115,0.051,0.051],[0.043,0.142,0.037],[2.358,2.391,2.109],[2.268,2.077,2.307],[0.631,0.570,0.489],[0.818,0.713,0.618],[2.549,1.825,1.830],[4.198,3.951,2.743],[2.807,3.502,2.802],[1.953,1.725,1.664],[6.334,9.059,6.298],[7.006,6.664,7.313],[17.971,24.901,23.878],[0.062,0.170,0.007],[12.547,1.468,1.455],[5.785,0.463,3.810],[19.587,2.191,4.475],[32.062,2.038,4.260],[1.146,0.998,1.046],[0.691,0.682,0.688],[0.995,1.024,1.061],[3.285,3.297,3.365],[43.259,35.553,35.500],[0.121,0.118,0.238],[2.392,1.833,2.171],[5.358,2.571,2.479],[14.690,16.282,14.550],[15.419,14.292,14.038],[14.424,14.949,14.887],[1.054,1.014,0.973],[0.189,0.103,0.104],[0.053,0.052,0.049],[0.046,0.048,0.047],[0.209,0.202,0.195],[0.031,0.135,0.031],[0.022,0.025,0.022],[0.020,0.019,0.018]],"source":"clickhouse-cloud/results/aws.2.12.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":58.345,"data_size":9952504953,"result":[[0.002,0.002,0.002],[0.017,0.367,0.013],[0.024,0.023,0.024],[0.432,0.037,0.036],[0.201,0.194,0.181],[0.249,0.227,0.389],[0.013,0.013,0.014],[0.017,0.089,0.016],[0.246,0.233,0.443],[0.294,0.438,0.274],[0.128,0.208,0.118],[0.138,0.136,0.133],[0.445,0.270,0.265],[0.384,0.424,0.395],[0.433,0.321,0.321],[0.228,0.213,0.202],[0.754,0.782,0.746],[0.571,0.623,0.648],[1.496,1.702,1.364],[0.073,0.005,0.005],[1.150,0.409,0.218],[0.439,0.446,0.064],[0.526,1.410,0.303],[0.403,0.396,0.397],[0.139,0.139,0.139],[0.105,0.102,0.104],[0.133,0.137,0.135],[0.396,0.404,0.473],[4.376,3.591,3.705],[0.037,0.036,0.036],[0.255,0.570,0.267],[0.376,0.374,0.989],[1.338,1.151,1.365],[1.085,1.110,1.138],[1.097,1.072,1.100],[0.184,0.181,0.155],[0.138,0.039,0.049],[0.029,0.026,0.026],[0.186,0.029,0.029],[0.067,0.265,0.068],[0.203,0.018,0.017],[0.017,0.167,0.017],[0.015,0.013,0.014]],"source":"clickhouse-cloud/results/aws.2.120.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":240.639,"data_size":9941146231,"result":[[0.002,0.002,0.002],[0.508,0.023,0.055],[0.603,0.093,0.095],[0.448,0.165,0.173],[0.799,1.304,0.806],[1.578,1.438,1.333],[0.041,0.042,0.106],[0.024,0.083,0.025],[1.204,1.190,1.063],[1.808,1.742,1.592],[0.500,0.387,0.382],[0.582,0.570,0.472],[1.814,1.404,1.673],[2.994,2.650,2.562],[2.260,2.004,1.913],[1.491,1.026,1.009],[4.668,4.787,5.718],[3.471,4.751,4.420],[9.635,12.849,13.213],[0.051,0.006,0.007],[3.248,9.322,1.094],[2.826,3.603,0.289],[4.074,2.121,1.926],[28.951,1.456,1.441],[0.723,0.747,1.045],[0.596,0.599,0.498],[0.739,0.932,0.734],[2.488,3.068,2.411],[33.978,28.139,32.018],[0.337,0.092,0.091],[1.327,2.399,1.379],[3.773,2.090,2.011],[12.764,11.078,11.900],[12.661,6.703,6.703],[6.515,11.378,6.630],[0.823,0.859,0.718],[0.297,0.085,0.078],[0.190,0.043,0.044],[0.043,0.153,0.042],[0.239,0.135,0.133],[0.177,0.024,0.023],[0.022,0.126,0.020],[0.134,0.019,0.024]],"source":"clickhouse-cloud/results/aws.2.16.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 236GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":55.262,"data_size":9952463416,"result":[[0.002,0.002,0.002],[0.018,0.472,0.016],[0.220,0.023,0.022],[0.217,0.027,0.028],[0.124,0.115,0.110],[0.312,0.168,0.292],[0.015,0.015,0.015],[0.131,0.019,0.018],[0.409,0.332,0.293],[0.308,0.361,0.313],[0.295,0.100,0.109],[0.203,0.110,0.099],[0.233,0.196,0.162],[0.253,0.259,0.278],[0.227,0.216,0.312],[0.123,0.118,0.118],[0.470,0.400,0.469],[0.283,0.299,0.312],[1.024,0.716,0.721],[0.016,0.005,0.063],[0.797,0.146,0.155],[0.281,0.054,0.051],[0.707,0.365,0.200],[0.403,0.315,0.295],[0.099,0.100,0.100],[0.069,0.080,0.079],[0.100,0.100,0.100],[0.358,0.268,0.269],[2.327,1.973,1.901],[0.258,0.042,0.041],[0.191,0.184,0.191],[0.637,0.258,0.230],[0.979,0.835,0.843],[0.807,0.772,0.762],[0.732,0.741,0.793],[0.099,0.101,0.092],[0.172,0.047,0.050],[0.031,0.031,0.030],[0.031,0.031,0.131],[0.197,0.081,0.082],[0.019,0.019,0.185],[0.019,0.018,0.018],[0.015,0.015,0.015]],"source":"clickhouse-cloud/results/aws.2.236.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":106.553,"data_size":9946797199,"result":[[0.002,0.003,0.019],[0.215,0.016,0.015],[0.514,0.056,0.082],[0.233,0.085,0.104],[0.595,0.516,0.481],[0.837,0.831,0.826],[0.100,0.024,0.024],[0.018,0.018,0.018],[0.622,0.539,0.640],[0.690,0.947,0.705],[0.322,0.247,0.243],[0.299,0.289,0.287],[0.731,0.748,0.786],[1.182,1.041,1.151],[0.994,1.018,1.097],[0.690,0.513,0.594],[2.339,2.649,2.408],[1.565,1.523,1.559],[4.590,4.638,4.693],[0.029,0.099,0.005],[4.438,0.578,0.568],[1.428,0.135,0.134],[1.833,5.340,0.800],[1.721,37.517,0.892],[0.424,0.405,0.403],[0.286,0.260,null],[0.406,0.401,0.422],[1.428,1.267,1.201],[15.666,13.090,13.337],[0.404,0.060,0.060],[0.723,1.351,0.750],[2.051,1.046,0.920],[3.845,2.711,2.520],[3.213,3.252,3.183],[3.144,3.294,5.668],[0.458,0.469,0.451],[0.196,0.050,0.047],[0.150,0.031,0.031],[0.032,0.030,0.139],[0.081,0.083,0.206],[0.167,0.018,0.018],[0.017,0.128,0.018],[0.016,0.120,0.017]],"source":"clickhouse-cloud/results/aws.2.32.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":59.979,"data_size":9937891951,"result":[[0.003,0.002,0.002],[0.015,0.013,0.251],[0.271,0.033,0.034],[0.052,0.211,0.053],[0.253,0.252,0.252],[0.529,0.404,0.426],[0.107,0.017,0.017],[0.052,0.016,0.015],[0.546,0.372,0.346],[0.417,0.437,0.437],[0.156,0.250,0.159],[0.287,0.185,0.182],[0.469,0.412,0.422],[0.628,0.595,0.638],[0.547,0.661,0.627],[0.289,0.254,0.292],[1.137,1.121,1.161],[0.819,0.822,0.892],[2.728,2.296,2.522],[0.018,0.076,0.005],[2.043,0.322,0.687],[0.747,0.085,0.085],[0.915,2.539,0.460],[0.531,32.647,0.523],[0.214,0.224,0.212],[0.163,0.161,0.168],[0.212,0.211,0.247],[0.658,0.676,0.676],[8.167,7.159,7.021],[0.043,0.043,0.042],[0.679,0.418,0.415],[0.548,0.525,1.293],[1.625,1.911,1.361],[1.685,1.907,1.784],[1.873,1.774,1.789],[0.389,0.242,0.278],[0.040,0.267,0.043],[0.026,0.030,0.141],[0.120,0.027,0.029],[0.071,0.280,0.068],[0.019,0.019,0.237],[0.114,0.016,0.017],[0.013,0.013,0.194]],"source":"clickhouse-cloud/results/aws.2.64.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":482.483,"data_size":9943634620,"result":[[0.002,0.015,0.002],[0.033,0.163,0.046],[0.260,0.282,0.189],[0.447,0.455,0.465],[1.982,2.507,2.398],[3.342,4.586,4.365],[0.139,0.073,0.072],[0.036,0.036,0.035],[3.239,3.474,3.383],[4.058,3.170,4.218],[1.153,0.839,0.733],[1.526,0.977,0.954],[2.647,4.515,4.479],[4.155,6.671,7.050],[5.674,4.223,5.646],[2.962,2.958,2.868],[19.511,14.962,14.324],[17.144,14.839,14.768],[30.210,31.285,25.850],[0.085,0.214,0.010],[5.179,18.508,2.437],[5.715,0.537,0.509],[21.309,6.538,3.046],[28.008,2.904,2.873],[1.754,1.449,1.448],[1.002,0.992,0.961],[1.479,1.429,1.523],[4.922,4.922,4.738],[54.170,64.798,53.582],[0.165,0.242,0.165],[2.599,3.613,2.488],[3.691,3.482,3.215],[20.351,20.255,19.727],[21.343,22.225,22.050],[21.317,21.526,21.630],[1.527,1.487,1.348],[0.175,0.146,0.155],[0.065,0.066,0.066],[0.070,0.066,0.061],[0.296,0.430,0.268],[0.035,0.033,0.033],[0.028,0.157,0.026],[0.026,0.023,0.024]],"source":"clickhouse-cloud/results/aws.2.8.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":316.908,"data_size":9941060505,"result":[[0.002,0.002,0.002],[0.092,0.061,0.386],[0.273,0.167,0.118],[0.393,0.327,0.477],[1.745,1.967,1.042],[2.388,2.428,2.135],[0.138,0.050,0.050],[0.030,0.098,0.027],[1.390,1.615,1.242],[1.652,1.664,1.668],[0.575,0.596,0.540],[0.662,0.624,0.589],[1.773,2.661,1.846],[2.537,2.627,2.696],[2.558,2.342,3.638],[1.246,1.180,1.789],[14.297,5.840,8.897],[4.372,6.715,5.015],[18.529,15.821,16.099],[0.071,0.168,0.007],[4.809,12.706,1.479],[7.752,0.320,0.407],[12.630,1.979,1.942],[32.115,31.216,18.811],[1.042,1.318,1.208],[0.677,0.663,0.645],[0.962,1.007,0.947],[3.087,3.319,3.082],[40.769,34.823,34.592],[0.264,0.111,0.110],[1.887,2.166,1.887],[5.193,2.691,3.577],[17.464,13.874,14.055],[14.064,13.148,13.642],[14.446,13.467,14.196],[0.972,0.931,0.982],[0.165,0.104,0.100],[0.186,0.050,0.135],[0.046,0.048,0.050],[0.204,0.195,0.348],[0.181,0.029,0.027],[0.021,0.021,0.093],[0.019,0.018,0.018]],"source":"clickhouse-cloud/results/aws.3.12.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":59.832,"data_size":9936791046,"result":[[0.002,0.002,0.002],[0.442,0.050,0.050],[0.134,0.392,0.027],[0.353,0.034,0.034],[0.270,0.202,0.178],[0.372,0.280,0.276],[0.015,0.015,0.129],[0.075,0.015,0.050],[0.424,0.350,0.246],[0.307,0.300,0.394],[0.258,0.182,0.124],[0.277,0.147,0.125],[0.377,0.310,0.284],[0.477,0.468,0.419],[0.456,0.593,0.372],[0.215,0.174,0.256],[0.782,0.718,0.787],[0.630,0.558,0.585],[1.684,1.402,1.540],[0.091,0.075,0.015],[1.326,0.916,0.187],[0.451,0.451,0.060],[1.477,0.530,0.259],[36.169,0.410,22.395],[0.143,0.143,0.140],[0.107,0.102,0.106],[0.139,0.143,0.143],[0.424,0.395,0.377],[4.494,3.749,3.708],[0.036,0.036,0.035],[0.411,0.270,0.245],[0.366,0.354,0.329],[2.204,1.636,1.617],[1.125,1.177,1.098],[1.052,1.127,1.060],[0.161,0.189,0.137],[0.041,0.046,0.042],[0.215,0.031,0.126],[0.121,0.087,0.033],[0.073,0.072,0.164],[0.149,0.088,0.021],[0.017,0.017,0.186],[0.098,0.113,0.014]],"source":"clickhouse-cloud/results/aws.3.120.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":219.069,"data_size":9940380641,"result":[[0.005,0.018,0.002],[0.184,0.042,0.018],[0.227,0.184,0.114],[0.407,0.393,0.166],[0.816,1.228,0.777],[1.447,1.435,1.598],[0.112,0.111,0.039],[0.024,0.151,0.024],[1.246,1.208,1.125],[1.454,1.204,1.328],[0.440,0.486,0.454],[0.543,0.501,0.570],[1.514,1.312,1.247],[1.835,2.651,1.990],[1.855,1.824,1.687],[1.195,1.171,0.954],[4.033,5.512,3.968],[2.950,4.184,3.047],[13.120,8.136,16.729],[0.047,0.136,0.006],[3.033,9.325,1.063],[5.952,3.450,2.724],[4.115,9.524,1.468],[34.905,1.889,1.462],[0.732,0.819,0.887],[0.602,0.492,0.487],[0.730,0.717,0.894],[2.369,2.378,2.492],[31.312,30.555,26.169],[0.615,0.088,0.089],[1.302,2.459,1.743],[1.925,4.138,2.911],[11.568,10.766,11.708],[12.250,10.766,6.178],[6.293,10.552,6.106],[0.801,0.864,0.702],[0.286,0.312,0.078],[0.157,0.040,0.100],[0.130,0.043,0.148],[0.141,0.143,0.142],[0.169,0.022,0.022],[0.138,0.137,0.021],[0.132,0.019,0.016]],"source":"clickhouse-cloud/results/aws.3.16.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 236GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":55.196,"data_size":9947181162,"result":[[0.002,0.002,0.002],[0.373,0.319,0.068],[0.182,0.024,0.173],[0.222,0.169,0.026],[0.126,0.111,0.109],[0.319,0.173,0.160],[0.015,0.015,0.016],[0.100,0.072,0.017],[0.293,0.490,0.277],[0.321,0.312,0.421],[0.239,0.206,0.110],[0.233,0.100,0.118],[0.347,0.154,0.293],[0.266,0.232,0.237],[0.298,0.232,0.214],[0.127,0.122,0.130],[0.420,0.443,0.430],[0.256,0.257,0.251],[1.090,0.954,1.021],[0.062,0.051,0.004],[0.747,1.154,0.148],[0.294,0.286,0.050],[0.360,0.202,0.201],[34.107,0.416,22.148],[0.094,0.090,0.089],[0.066,0.064,0.067],[0.091,0.089,0.090],[0.283,0.307,0.269],[1.943,2.473,1.943],[0.044,0.042,0.041],[0.446,0.180,0.170],[0.253,0.679,0.225],[0.972,1.246,0.821],[0.791,0.789,0.801],[0.785,0.761,0.725],[0.495,0.098,0.092],[0.250,0.042,0.220],[0.135,0.027,0.029],[0.029,0.028,0.120],[0.327,0.072,0.200],[0.017,0.153,0.080],[0.132,0.017,0.017],[0.118,0.013,0.014]],"source":"clickhouse-cloud/results/aws.3.236.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":109.124,"data_size":9945232800,"result":[[0.002,0.002,0.025],[0.657,0.061,0.020],[0.076,0.520,0.208],[0.121,0.223,0.219],[0.497,0.649,0.490],[0.838,0.887,0.897],[0.027,0.029,0.093],[0.081,0.018,0.017],[0.623,0.579,0.654],[0.703,0.680,0.620],[0.261,0.332,0.357],[0.406,0.307,0.376],[0.762,0.815,0.711],[1.201,1.071,1.104],[1.097,1.100,1.071],[0.605,0.472,0.455],[2.258,2.071,2.741],[1.694,1.746,1.507],[4.246,4.761,4.793],[0.102,0.006,0.028],[1.397,0.648,4.091],[1.379,1.597,3.126],[1.824,4.423,0.778],[36.830,0.923,0.819],[0.434,0.418,0.918],[0.307,0.297,0.277],[0.400,0.439,0.395],[1.242,1.185,1.183],[15.532,14.357,14.866],[0.281,0.142,0.059],[1.303,0.974,0.688],[2.056,0.890,1.462],[3.993,2.752,2.741],[3.212,5.721,3.269],[3.256,3.285,3.250],[0.386,0.376,0.374],[0.049,0.225,0.050],[0.136,0.130,0.029],[0.184,0.030,0.081],[0.083,0.215,0.079],[0.138,0.017,0.106],[0.157,0.017,0.187],[0.144,0.078,0.016]],"source":"clickhouse-cloud/results/aws.3.32.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":59.040,"data_size":9946816484,"result":[[0.002,0.002,0.002],[0.337,0.302,0.012],[0.170,0.128,0.116],[0.051,0.057,0.162],[0.247,0.217,0.306],[0.522,0.372,0.430],[0.134,0.016,0.066],[0.186,0.014,0.015],[0.457,0.432,0.350],[0.406,0.399,0.399],[0.159,0.251,0.226],[0.265,0.224,0.176],[0.465,0.521,0.394],[0.598,0.549,0.625],[0.545,0.554,0.613],[0.292,0.271,0.292],[1.124,1.053,1.169],[0.814,0.837,0.964],[2.501,2.437,2.379],[0.067,0.005,0.019],[0.707,1.928,0.333],[0.744,0.781,1.590],[2.186,1.717,0.916],[0.531,30.644,0.508],[0.474,0.211,0.205],[0.151,0.153,0.150],[0.210,0.210,0.223],[0.708,0.680,0.675],[8.046,7.259,6.606],[0.043,0.043,0.042],[0.656,0.421,0.418],[1.197,0.550,0.510],[1.578,2.985,2.321],[2.204,1.888,3.007],[1.868,2.289,1.841],[0.475,0.297,0.256],[0.049,0.242,0.210],[0.026,0.159,0.025],[0.028,0.123,0.029],[0.315,0.075,0.175],[0.143,0.017,0.017],[0.141,0.017,0.016],[0.169,0.077,0.014]],"source":"clickhouse-cloud/results/aws.3.64.json"}
-,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":476.531,"data_size":9946351549,"result":[[0.002,0.002,0.002],[0.224,0.160,0.027],[0.338,0.319,0.169],[0.946,0.672,0.668],[1.486,1.546,1.502],[2.968,2.627,6.236],[0.149,0.127,0.077],[0.049,0.042,0.038],[3.930,2.510,2.082],[4.279,2.479,4.700],[0.809,1.222,0.750],[0.963,1.493,1.443],[2.559,2.843,4.612],[4.165,3.875,7.514],[4.406,7.883,3.819],[3.241,1.920,2.186],[13.007,23.094,12.788],[16.745,10.066,11.276],[28.570,26.280,24.545],[0.179,0.009,0.152],[18.735,11.138,2.133],[6.212,5.517,6.038],[19.873,12.144,6.836],[6.136,23.215,2.944],[1.496,1.503,1.500],[1.030,1.008,0.983],[1.514,1.450,1.503],[5.227,5.118,5.059],[64.225,55.203,53.686],[0.165,0.335,0.205],[3.406,3.105,2.768],[3.977,3.834,7.062],[28.491,22.055,20.914],[21.085,21.192,21.247],[22.470,21.408,20.993],[1.362,1.438,1.328],[0.273,0.148,0.145],[0.073,0.076,0.068],[0.066,0.064,0.066],[0.289,0.309,0.427],[0.160,0.034,0.035],[0.119,0.032,0.099],[0.025,0.024,0.025]],"source":"clickhouse-cloud/results/aws.3.8.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":336.387,"data_size":9942318871,"result":[[0.003,0.002,0.002],[0.028,0.025,0.025],[0.224,0.204,0.199],[0.379,0.298,0.239],[1.598,1.583,1.685],[3.268,2.961,2.767],[0.031,0.030,0.029],[0.023,0.024,0.025],[2.512,2.291,2.237],[3.455,2.410,2.174],[0.520,0.519,0.545],[0.654,0.683,0.568],[2.111,2.175,2.309],[3.481,3.535,3.374],[3.124,2.764,2.991],[1.807,1.864,1.737],[15.827,13.349,8.492],[8.813,8.261,8.267],[22.759,21.345,22.062],[0.057,0.007,0.007],[3.877,1.727,1.676],[4.449,0.383,0.311],[4.971,2.269,2.336],[2.423,2.102,2.118],[1.143,1.133,1.113],[0.769,0.776,0.806],[1.201,1.224,0.923],[3.587,3.718,3.397],[46.660,47.539,45.014],[0.138,0.121,0.110],[2.345,2.298,2.267],[2.686,2.385,1.994],[13.546,14.479,14.448],[13.535,14.914,14.404],[13.476,12.882,13.482],[1.001,1.032,0.884],[0.102,0.108,0.099],[0.046,0.052,0.040],[0.038,0.044,0.040],[0.202,0.178,0.180],[0.026,0.024,0.025],[0.019,0.018,0.017],[0.019,0.017,0.014]],"source":"clickhouse-cloud/results/azure.1.12.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":637.866,"data_size":9947491120,"result":[[0.003,0.002,0.002],[0.069,0.073,0.022],[0.344,0.381,0.403],[0.782,0.523,0.592],[3.175,3.277,3.092],[4.753,4.382,4.132],[0.044,0.045,0.046],[0.033,0.029,0.030],[3.704,3.800,3.337],[4.013,4.804,4.607],[1.071,0.956,0.740],[1.120,1.013,1.260],[4.280,4.133,4.368],[7.257,12.797,6.685],[6.753,6.387,5.700],[3.403,3.302,3.682],[23.530,21.901,15.839],[12.543,11.669,11.708],[34.306,32.809,31.370],[0.089,0.010,0.008],[4.946,1.970,1.912],[5.360,0.447,0.486],[6.667,3.159,2.692],[2.581,2.481,2.500],[1.332,1.291,1.286],[0.938,0.920,0.907],[1.358,1.310,1.276],[4.977,4.508,4.649],[51.330,48.769,48.890],[0.166,0.156,0.144],[2.581,2.459,2.555],[3.503,3.574,3.522],[24.452,24.944,26.063],[23.922,24.954,23.756],[23.763,23.530,23.584],[1.485,1.440,1.497],[0.161,0.133,0.145],[0.067,0.065,0.058],[0.057,0.075,0.057],[0.302,0.273,0.295],[0.030,0.027,0.026],[0.022,0.022,0.026],[0.022,0.018,0.019]],"source":"clickhouse-cloud/results/azure.1.8.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":340.687,"data_size":9940842756,"result":[[0.003,0.005,0.002],[0.027,1.164,0.028],[0.390,0.110,0.148],[1.335,0.182,0.303],[1.609,1.280,1.204],[3.115,2.970,3.461],[0.093,0.032,0.039],[0.181,0.026,0.068],[1.870,1.650,1.611],[2.195,1.979,2.301],[0.486,0.507,0.477],[0.577,0.604,0.556],[2.095,2.714,2.115],[3.037,3.342,2.433],[2.882,3.465,3.659],[2.113,1.733,1.505],[14.074,11.037,14.365],[6.579,9.637,10.213],[29.392,19.233,31.548],[0.063,0.007,0.054],[4.517,1.963,1.950],[4.602,3.278,0.278],[5.981,2.695,3.779],[2.671,3.541,2.385],[0.818,0.826,0.836],[0.880,0.570,0.881],[0.821,1.358,0.850],[2.776,3.927,2.783],[49.782,46.848,46.188],[0.450,0.121,0.134],[2.280,1.753,4.812],[15.231,3.114,2.262],[20.424,20.297,19.476],[17.132,43.294,15.999],[15.601,13.856,13.282],[1.128,1.098,1.095],[0.101,0.093,0.092],[0.053,0.066,0.043],[0.043,0.039,0.037],[0.263,0.183,0.171],[0.021,0.027,0.020],[0.016,0.019,0.015],[0.016,0.016,0.017]],"source":"clickhouse-cloud/results/azure.2.12.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":103.423,"data_size":9949842171,"result":[[0.002,0.002,0.002],[0.016,5.204,0.024],[0.027,0.955,0.032],[1.222,0.405,0.035],[0.236,0.334,0.228],[0.288,5.627,0.276],[0.011,0.061,0.011],[0.014,0.017,0.052],[0.296,0.396,0.310],[0.313,0.342,0.358],[0.219,0.144,0.140],[0.188,0.142,0.144],[0.353,0.314,0.300],[0.453,0.613,0.426],[0.376,0.359,0.351],[0.291,0.288,0.244],[0.920,0.903,0.918],[0.751,0.639,0.647],[1.768,7.161,2.032],[0.065,0.018,0.005],[8.344,0.431,0.226],[0.532,0.501,0.075],[0.589,6.309,0.332],[0.396,0.381,0.372],[0.173,0.144,0.160],[0.111,0.115,0.129],[0.175,0.158,0.161],[0.455,0.457,0.526],[4.359,4.470,10.058],[0.036,0.036,0.190],[0.477,0.310,0.338],[6.590,0.456,0.446],[1.954,2.106,1.737],[1.547,1.319,1.442],[1.339,1.301,1.253],[0.212,0.252,0.194],[0.046,0.051,0.064],[0.028,0.030,0.028],[0.030,0.028,0.037],[0.072,0.079,0.079],[0.017,0.017,0.021],[0.017,0.017,0.018],[0.013,0.012,0.013]],"source":"clickhouse-cloud/results/azure.2.120.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":261.491,"data_size":9941460074,"result":[[0.002,0.002,0.002],[0.027,0.594,0.027],[0.452,0.137,0.122],[1.432,0.241,0.150],[0.953,1.369,1.236],[2.040,1.677,1.588],[0.035,0.117,0.022],[0.046,0.022,0.019],[1.323,1.294,1.397],[1.589,1.553,1.451],[1.948,0.362,0.371],[0.453,0.413,0.470],[2.606,2.123,1.534],[2.609,2.790,2.263],[2.295,2.083,1.959],[1.495,1.236,1.498],[6.136,6.089,6.196],[3.759,4.001,3.428],[11.740,10.751,15.442],[0.055,0.006,0.006],[7.405,2.817,1.146],[2.996,0.245,0.237],[4.167,1.596,3.810],[1.871,1.322,1.671],[0.659,0.641,0.641],[0.618,0.556,0.567],[0.664,0.729,0.844],[2.097,2.912,2.763],[28.983,29.753,24.931],[0.081,0.085,0.079],[1.845,1.184,1.170],[1.749,2.724,1.484],[17.430,11.545,15.666],[8.656,7.092,25.380],[8.082,6.711,8.323],[1.021,0.932,0.761],[0.143,0.088,0.084],[0.037,0.241,0.046],[0.042,0.043,0.050],[0.252,0.153,0.170],[0.264,0.026,0.021],[0.017,0.110,0.020],[0.017,0.019,0.017]],"source":"clickhouse-cloud/results/azure.2.16.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":119.682,"data_size":9949037675,"result":[[0.002,0.002,0.002],[0.025,0.021,0.014],[0.998,0.073,0.063],[1.023,0.117,0.179],[0.791,0.564,0.530],[0.921,1.427,0.806],[0.056,0.023,0.020],[0.048,0.019,0.015],[0.970,0.633,0.698],[0.764,0.782,0.989],[0.261,0.170,0.188],[0.302,0.233,0.250],[0.757,0.800,0.685],[1.122,1.099,1.035],[0.951,1.171,1.122],[0.815,0.853,0.675],[2.743,2.953,2.545],[1.735,1.636,1.826],[4.837,5.308,5.129],[0.070,0.005,0.006],[8.909,0.601,1.254],[1.388,1.447,0.156],[1.714,5.187,0.829],[0.814,0.850,0.821],[0.404,0.413,0.407],[0.265,0.263,0.307],[0.371,0.404,0.366],[1.205,1.144,1.167],[16.842,14.874,13.161],[0.248,0.059,0.065],[0.738,0.678,0.694],[1.911,1.144,0.925],[4.854,3.352,3.760],[3.232,3.346,3.636],[3.282,3.693,3.384],[0.530,0.468,0.491],[0.070,0.056,0.057],[0.029,0.030,0.036],[0.033,0.033,0.037],[0.104,0.109,0.108],[0.017,0.018,0.020],[0.018,0.019,0.016],[0.012,0.013,0.014]],"source":"clickhouse-cloud/results/azure.2.32.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-08","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":114.282,"data_size":9948906386,"result":[[0.002,0.002,0.002],[0.211,0.019,0.023],[0.324,0.043,0.194],[0.062,0.553,0.053],[0.358,0.334,0.373],[0.520,0.962,0.452],[0.276,0.015,0.014],[0.017,0.018,0.059],[0.694,0.424,0.402],[0.527,0.527,0.487],[0.339,0.179,0.162],[0.176,0.182,0.238],[0.653,0.487,0.445],[1.004,0.699,0.709],[0.729,0.677,0.622],[0.349,0.306,0.327],[1.283,1.493,1.456],[0.907,0.950,1.136],[3.820,2.794,2.937],[0.067,0.006,0.006],[0.665,0.334,4.786],[1.765,0.741,0.093],[0.863,3.407,0.485],[20.249,0.557,0.525],[0.233,0.230,0.225],[0.172,0.167,0.166],[0.229,0.262,0.210],[0.711,0.650,0.651],[7.541,8.028,7.773],[0.078,0.053,0.041],[0.743,0.425,0.473],[0.689,0.523,2.267],[2.073,2.462,2.110],[1.973,2.338,2.097],[2.055,1.955,2.415],[0.268,0.263,0.301],[0.043,0.048,0.076],[0.037,0.031,0.032],[0.028,0.028,0.027],[0.089,0.088,0.083],[0.027,0.029,0.027],[0.020,0.018,0.017],[0.016,0.013,0.015]],"source":"clickhouse-cloud/results/azure.2.64.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":773.632,"data_size":9943107896,"result":[[0.003,0.004,0.003],[0.194,0.095,0.027],[0.511,0.397,0.706],[0.777,0.411,0.375],[6.080,2.219,2.168],[8.098,2.972,8.619],[0.107,0.077,0.043],[0.046,0.042,0.028],[8.404,2.232,2.290],[9.465,3.214,3.038],[0.659,0.668,2.084],[0.794,2.312,0.857],[9.614,9.335,2.695],[15.681,22.825,12.811],[9.757,6.303,5.346],[6.471,7.074,6.299],[35.596,32.184,15.943],[11.440,17.528,18.870],[43.285,43.121,42.337],[0.097,0.015,0.131],[10.303,3.021,3.196],[7.438,0.557,0.589],[8.815,6.911,2.853],[6.978,2.845,2.616],[1.495,1.692,1.605],[0.942,1.075,0.939],[2.094,1.786,1.365],[4.647,6.007,4.595],[68.024,67.897,52.971],[0.214,0.202,0.180],[2.847,2.777,2.579],[3.762,3.788,7.249],[28.151,25.537,53.371],[35.585,24.017,35.645],[34.680,33.338,31.862],[1.596,2.667,1.476],[0.226,0.180,0.163],[0.136,0.085,0.082],[0.083,0.081,0.073],[0.437,0.305,0.409],[0.031,0.050,0.030],[0.021,0.033,0.032],[0.026,0.018,0.027]],"source":"clickhouse-cloud/results/azure.2.8.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":453.354,"data_size":9946513248,"result":[[0.008,0.003,0.002],[0.339,0.022,0.021],[6.040,0.439,0.367],[0.769,1.364,0.228],[1.552,2.868,3.033],[4.775,5.989,4.597],[0.111,0.028,0.085],[0.040,0.032,0.034],[2.275,2.058,3.126],[2.281,2.611,5.225],[1.230,0.552,2.100],[1.007,0.645,1.208],[2.204,1.835,2.107],[4.203,8.219,3.744],[6.243,3.138,2.760],[3.715,1.683,2.223],[16.545,8.131,15.982],[5.393,4.559,7.464],[22.402,21.156,40.545],[0.075,0.008,0.010],[3.163,3.528,6.426],[3.244,7.164,0.580],[4.064,1.920,1.868],[1.986,1.864,1.761],[1.956,0.927,2.092],[0.620,1.116,1.100],[0.899,1.629,1.753],[2.831,5.788,3.098],[63.948,46.051,44.624],[0.162,0.119,0.109],[2.181,2.126,5.134],[4.831,15.763,3.241],[23.589,15.417,21.900],[15.862,14.723,14.231],[23.738,14.114,15.007],[2.016,1.146,1.033],[0.114,0.190,0.099],[0.075,0.059,0.054],[0.044,0.062,0.066],[0.201,0.180,0.229],[0.036,0.039,0.029],[0.018,0.017,0.018],[0.025,0.019,0.020]],"source":"clickhouse-cloud/results/azure.3.12.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":116.139,"data_size":9951013990,"result":[[0.002,0.002,0.002],[5.164,0.017,0.054],[0.314,5.281,0.105],[5.344,5.374,0.036],[0.443,0.218,0.259],[5.414,0.285,5.331],[0.014,0.132,0.131],[0.016,0.014,0.058],[0.300,0.262,0.265],[0.549,0.321,0.361],[0.410,0.175,0.137],[0.145,0.148,0.263],[0.363,0.533,0.476],[0.543,1.563,0.439],[0.517,0.409,0.416],[0.291,0.252,0.270],[0.957,0.913,0.978],[0.650,0.686,0.662],[1.828,6.037,1.700],[0.074,0.019,0.047],[10.458,0.398,0.234],[0.500,0.085,7.424],[0.546,6.596,0.325],[24.902,20.389,0.387],[0.157,0.149,0.160],[0.127,0.113,0.111],[0.158,0.150,0.135],[0.427,0.489,0.406],[4.524,6.678,4.301],[0.035,0.040,0.036],[0.275,0.280,0.277],[1.011,0.440,0.374],[2.181,2.252,1.470],[1.395,1.323,1.298],[1.222,1.336,1.432],[0.231,0.175,0.245],[0.051,0.044,0.045],[0.034,0.029,0.030],[0.033,0.031,0.034],[0.086,0.101,0.078],[0.017,0.025,0.018],[0.017,0.018,0.017],[0.013,0.014,0.013]],"source":"clickhouse-cloud/results/azure.3.120.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-08","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":327.282,"data_size":9941159518,"result":[[0.003,0.027,0.002],[0.029,5.111,0.017],[5.216,0.150,0.322],[0.259,0.819,5.314],[0.902,0.961,1.075],[1.915,2.488,2.222],[0.053,0.025,0.027],[0.087,0.027,0.017],[2.005,1.239,2.058],[2.486,2.661,1.406],[0.467,0.365,0.364],[0.380,0.580,0.574],[2.723,2.366,5.590],[6.570,2.241,1.930],[1.725,3.988,1.859],[2.728,1.249,1.457],[12.268,5.135,10.377],[5.675,3.509,3.132],[31.680,22.943,9.057],[0.045,0.073,0.059],[2.253,1.016,5.350],[2.498,2.926,0.248],[2.983,5.018,1.302],[1.304,1.241,1.268],[0.687,0.638,0.977],[0.457,0.508,0.667],[1.033,1.000,1.069],[2.201,3.480,2.120],[23.299,23.193,41.374],[0.086,0.104,0.089],[1.222,2.451,2.525],[1.883,4.641,1.613],[11.213,14.535,11.222],[6.269,6.882,30.627],[24.748,11.525,7.184],[1.049,1.588,0.924],[0.130,0.139,0.104],[0.183,0.052,0.047],[0.040,0.054,0.049],[0.219,0.286,0.260],[0.028,0.096,0.185],[0.117,0.107,0.016],[0.014,0.014,0.013]],"source":"clickhouse-cloud/results/azure.3.16.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":160.919,"data_size":9946662199,"result":[[0.002,0.002,0.004],[0.524,0.017,0.599],[0.881,0.074,0.053],[0.150,5.378,0.495],[5.478,1.053,0.984],[1.324,1.051,5.595],[0.144,0.111,0.026],[0.052,0.015,0.024],[5.501,5.532,0.542],[0.745,1.092,0.668],[7.314,2.114,0.206],[0.362,1.705,0.271],[5.898,1.207,1.281],[6.457,1.081,1.109],[1.126,1.609,0.891],[1.377,0.755,0.754],[5.366,2.820,4.554],[2.588,1.812,2.492],[9.731,10.782,5.256],[0.047,0.089,0.006],[10.912,14.756,0.544],[1.423,1.775,0.165],[13.382,0.767,2.248],[29.936,0.780,0.755],[0.464,1.126,0.350],[0.329,0.300,0.251],[0.358,0.465,0.336],[1.554,1.129,1.171],[15.470,14.932,24.073],[0.423,0.061,0.062],[6.669,7.251,0.691],[9.754,1.433,1.070],[12.650,3.684,10.704],[5.694,13.537,3.346],[15.320,3.352,3.306],[0.882,0.556,0.888],[0.085,0.090,0.062],[0.046,0.128,0.031],[0.040,0.036,0.032],[0.177,0.087,0.173],[0.180,0.024,0.027],[0.025,0.264,0.024],[0.015,0.014,0.014]],"source":"clickhouse-cloud/results/azure.3.32.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":100.421,"data_size":9948742131,"result":[[0.002,0.002,0.002],[5.132,0.047,0.179],[0.217,0.041,0.035],[0.568,0.543,0.057],[0.394,0.278,0.270],[5.497,1.120,0.670],[0.012,0.012,0.012],[0.057,0.049,0.015],[5.613,0.393,0.724],[0.702,0.747,0.400],[0.135,0.244,0.148],[0.161,0.177,0.229],[0.844,0.621,0.459],[0.709,0.627,0.613],[0.663,0.562,0.555],[0.582,0.512,0.686],[1.199,2.476,1.648],[0.861,0.876,1.315],[5.752,4.075,6.514],[0.081,0.020,0.007],[12.171,4.841,0.312],[0.724,0.091,0.684],[7.929,3.018,0.710],[17.360,0.738,0.761],[0.192,0.182,0.181],[0.136,0.158,0.203],[0.260,0.242,0.204],[0.576,0.959,0.672],[9.592,6.714,8.576],[0.056,0.243,0.043],[0.650,0.410,0.399],[1.511,0.551,7.594],[1.925,2.627,4.235],[2.989,3.120,1.783],[1.714,1.751,1.732],[0.451,0.316,0.439],[0.051,0.045,0.048],[0.070,0.043,0.032],[0.045,0.029,0.049],[0.089,0.088,0.093],[0.021,0.017,0.019],[0.026,0.024,0.017],[0.015,0.013,0.019]],"source":"clickhouse-cloud/results/azure.3.64.json"}
-,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":592.886,"data_size":9946459119,"result":[[0.003,0.011,0.003],[0.328,0.031,0.033],[0.231,0.334,0.786],[1.085,0.829,0.769],[4.126,5.587,5.205],[6.177,3.294,3.849],[0.049,0.055,0.052],[0.037,0.042,0.036],[3.393,5.671,2.928],[3.809,4.241,5.425],[1.671,1.908,0.576],[1.752,0.753,0.757],[5.087,10.029,9.079],[11.229,9.723,8.680],[3.983,3.348,3.399],[3.902,4.263,3.843],[23.097,21.958,13.480],[10.853,12.735,15.558],[42.892,88.999,43.798],[0.120,0.097,0.140],[5.157,1.954,2.008],[6.895,5.583,5.109],[8.226,6.173,3.729],[7.465,2.705,3.464],[1.395,1.288,1.283],[0.941,1.075,0.877],[1.777,1.714,1.301],[5.807,4.472,6.048],[53.778,54.059,50.211],[0.186,0.168,0.159],[4.264,2.398,2.288],[3.495,3.537,6.356],[24.000,20.761,22.749],[24.055,20.674,35.439],[21.753,22.826,23.397],[1.453,2.858,1.361],[0.140,0.259,0.152],[0.064,0.062,0.102],[0.079,0.057,0.056],[0.291,0.264,0.462],[0.034,0.033,0.045],[0.029,0.020,0.034],[0.021,0.023,0.030]],"source":"clickhouse-cloud/results/azure.3.8.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":396.562,"data_size":9940748285,"result":[[0.002,0.003,0.021],[0.101,0.049,0.023],[0.369,0.354,0.394],[0.505,0.427,0.405],[2.725,2.262,1.813],[2.725,2.688,2.816],[0.035,0.033,0.036],[0.024,0.023,0.030],[2.295,2.812,2.255],[2.670,2.704,2.366],[0.658,0.689,0.620],[0.812,0.789,0.818],[2.660,2.924,3.042],[4.301,4.309,4.235],[4.234,4.338,4.258],[2.361,2.519,2.321],[15.150,11.558,14.185],[7.838,12.266,11.127],[29.583,29.398,29.167],[0.062,0.008,0.008],[4.366,1.883,1.843],[5.149,0.399,0.425],[5.785,2.657,2.807],[2.546,2.525,2.438],[1.310,1.382,1.412],[0.877,0.877,0.878],[1.339,1.370,1.392],[4.266,4.644,4.551],[52.529,52.792,44.357],[0.131,0.123,0.109],[2.094,1.893,1.939],[2.695,2.640,2.477],[16.212,18.918,17.226],[15.312,15.849,15.215],[14.822,15.065,15.569],[1.318,1.270,1.168],[0.125,0.115,0.117],[0.049,0.056,0.044],[0.046,0.043,0.046],[0.232,0.219,0.231],[0.031,0.027,0.033],[0.020,0.023,0.019],[0.022,0.017,0.017]],"source":"clickhouse-cloud/results/gcp.1.12.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":671.129,"data_size":9947861043,"result":[[0.002,0.009,0.009],[0.073,0.059,0.051],[0.556,0.423,0.440],[0.657,0.661,0.899],[4.911,5.850,6.150],[7.535,9.210,9.351],[0.121,0.155,0.159],[0.144,0.089,0.131],[8.214,6.681,5.879],[7.484,7.445,5.357],[1.320,1.298,1.308],[1.766,1.785,1.616],[7.316,6.370,7.067],[10.374,14.043,8.855],[9.011,7.720,7.538],[4.867,4.565,4.980],[30.991,31.230,33.885],[24.160,18.906,19.925],[39.600,33.553,33.112],[0.079,0.011,0.011],[6.634,2.450,2.345],[5.579,0.532,0.486],[6.659,3.032,3.210],[3.089,2.793,3.452],[1.533,1.740,1.457],[1.133,1.089,1.183],[1.650,1.695,1.635],[5.824,5.881,5.837],[71.635,68.547,65.999],[0.198,0.199,0.242],[3.291,3.119,3.165],[4.368,4.357,4.029],[33.367,31.634,28.802],[24.193,23.568,26.193],[29.636,32.280,29.519],[2.334,2.124,2.163],[0.257,0.191,0.270],[0.103,0.076,0.080],[0.071,0.075,0.080],[0.413,0.431,0.377],[0.051,0.038,0.040],[0.041,0.035,0.034],[0.030,0.023,0.048]],"source":"clickhouse-cloud/results/gcp.1.8.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":438.637,"data_size":9942940238,"result":[[0.002,0.003,0.005],[0.059,0.039,0.319],[0.255,0.307,0.111],[0.634,0.160,0.167],[1.114,2.415,2.333],[2.296,4.390,1.800],[0.085,0.209,0.028],[0.101,0.032,0.134],[2.341,2.239,2.280],[3.234,2.513,1.688],[0.933,0.567,0.690],[0.871,0.956,0.996],[1.997,1.795,3.509],[2.932,5.720,5.192],[5.034,2.822,2.819],[1.542,2.712,1.425],[6.538,13.546,16.928],[4.335,8.452,13.677],[20.093,18.032,31.385],[0.338,0.008,0.088],[15.971,4.843,1.304],[3.431,5.811,0.554],[6.904,3.275,3.392],[3.639,39.224,1.723],[1.538,0.908,0.976],[1.384,0.616,0.992],[1.684,0.893,1.792],[3.952,16.257,4.322],[46.604,45.582,45.045],[0.149,0.147,0.131],[2.350,3.727,1.741],[7.052,3.516,2.223],[31.422,25.078,16.212],[20.641,20.753,15.126],[14.801,14.174,14.506],[1.229,1.190,1.446],[0.145,0.314,0.113],[0.315,0.077,0.057],[0.165,0.040,0.040],[0.261,0.283,0.207],[0.034,0.316,0.028],[0.031,0.348,0.021],[0.036,0.027,0.026]],"source":"clickhouse-cloud/results/gcp.2.12.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":75.616,"data_size":9951005106,"result":[[0.002,0.003,0.002],[0.531,0.027,0.019],[0.043,0.033,0.037],[0.046,0.039,0.393],[0.298,0.351,0.241],[0.312,0.310,0.593],[0.192,0.016,0.019],[0.018,0.165,0.019],[0.591,0.355,0.312],[0.380,0.738,0.452],[0.156,0.320,0.193],[0.427,0.168,0.194],[0.661,0.477,0.455],[0.662,0.678,0.621],[0.448,0.414,0.397],[0.284,0.248,0.249],[1.710,1.289,1.261],[0.772,0.735,0.720],[2.966,2.081,2.557],[0.021,0.125,0.007],[2.029,0.340,0.440],[0.633,0.128,0.112],[0.629,0.340,2.046],[0.445,44.064,0.587],[0.171,0.168,0.204],[0.132,0.106,0.115],[0.183,0.158,0.190],[0.452,0.472,0.475],[4.483,5.962,5.024],[0.041,0.178,0.041],[0.314,0.279,0.690],[0.452,1.183,0.518],[2.593,2.188,2.111],[1.800,1.540,1.713],[1.784,1.623,1.974],[0.268,0.365,0.246],[0.063,0.051,0.200],[0.037,0.045,0.036],[0.212,0.037,0.038],[0.248,0.102,0.105],[0.021,0.277,0.021],[0.199,0.023,0.022],[0.016,0.019,0.017]],"source":"clickhouse-cloud/results/gcp.2.120.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":287.557,"data_size":9943221654,"result":[[0.002,0.002,0.002],[0.051,0.403,0.023],[0.179,0.301,0.176],[0.310,0.261,0.607],[1.426,1.371,1.539],[1.829,1.391,1.260],[0.213,0.037,0.052],[0.097,0.026,0.023],[1.661,1.499,1.434],[1.476,1.283,1.393],[0.482,0.412,0.337],[0.586,0.431,0.454],[1.949,1.492,1.772],[3.107,2.367,2.131],[2.582,2.506,2.509],[1.546,1.266,2.040],[5.092,7.457,4.328],[4.273,4.710,3.309],[19.331,11.287,19.027],[0.274,0.052,0.008],[2.940,11.853,1.408],[3.469,0.330,2.581],[12.537,1.514,4.092],[1.897,38.773,1.328],[1.001,0.730,0.921],[0.621,0.625,0.636],[0.720,0.724,1.043],[2.305,2.244,2.275],[35.969,27.015,27.561],[0.309,0.106,0.089],[2.806,1.437,1.394],[2.404,2.339,5.276],[14.377,12.268,12.182],[16.050,11.316,6.737],[7.140,6.759,6.940],[1.012,0.983,0.928],[0.108,0.311,0.095],[0.048,0.276,0.053],[0.192,0.046,0.058],[0.546,0.183,0.163],[0.027,0.247,0.022],[0.285,0.022,0.023],[0.243,0.019,0.015]],"source":"clickhouse-cloud/results/gcp.2.16.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 236GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":90.293,"data_size":9950621157,"result":[[0.003,0.003,0.004],[0.487,0.027,0.026],[0.046,0.036,0.462],[0.046,0.289,0.153],[0.243,0.317,0.210],[0.256,0.250,0.551],[0.186,0.019,0.021],[0.027,0.027,0.027],[0.715,0.457,0.449],[0.426,0.493,0.469],[0.163,0.162,0.354],[0.348,0.154,0.169],[0.325,0.284,0.255],[0.554,0.439,0.419],[0.325,0.302,0.478],[0.243,0.227,0.191],[0.686,0.688,0.666],[0.541,0.499,0.612],[1.817,1.515,1.421],[0.027,0.007,0.105],[0.274,0.206,1.362],[0.998,0.345,0.088],[0.366,0.243,1.164],[46.769,0.389,0.354],[0.122,0.122,0.131],[0.088,0.092,0.096],[0.123,0.164,0.130],[0.382,0.381,0.521],[2.423,2.337,2.294],[0.168,0.045,0.046],[0.281,0.272,0.277],[0.413,0.345,0.337],[2.316,1.417,1.713],[1.143,1.052,1.386],[1.121,1.309,1.144],[0.143,0.159,0.148],[0.085,0.259,0.045],[0.042,0.038,0.049],[0.047,0.043,0.185],[0.120,0.351,0.098],[0.318,0.026,0.033],[0.182,0.022,0.023],[0.029,0.016,0.018]],"source":"clickhouse-cloud/results/gcp.2.236.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":147.070,"data_size":9945925540,"result":[[0.111,0.004,0.003],[0.096,1.115,0.134],[0.166,0.146,0.909],[1.185,0.162,0.142],[0.734,0.800,0.688],[1.076,1.118,1.288],[0.194,0.030,0.026],[0.019,0.019,0.021],[0.989,1.150,0.832],[0.963,0.999,1.101],[0.426,0.241,0.265],[0.493,0.354,0.338],[1.017,0.950,0.979],[1.564,1.542,1.513],[1.699,1.144,1.612],[0.929,0.899,0.803],[3.336,2.820,3.348],[1.789,1.871,1.806],[7.764,5.874,6.013],[0.175,0.008,0.033],[1.325,6.019,0.533],[1.412,0.573,0.159],[6.437,1.703,0.872],[43.253,0.808,0.869],[0.383,0.386,0.422],[0.275,0.286,0.292],[0.397,0.377,0.383],[1.257,1.351,1.287],[19.010,15.247,15.798],[0.069,0.062,0.183],[1.240,0.882,0.818],[2.982,1.323,1.534],[4.102,4.013,4.337],[4.374,4.256,4.065],[4.060,4.318,4.388],[0.535,0.685,0.597],[0.059,0.199,0.083],[0.038,0.051,0.048],[0.168,0.050,0.036],[0.116,0.106,0.271],[0.023,0.293,0.021],[0.166,0.022,0.021],[0.016,0.016,0.019]],"source":"clickhouse-cloud/results/gcp.2.32.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":85.551,"data_size":9946772558,"result":[[0.003,0.002,0.002],[0.562,0.024,0.023],[0.052,0.389,0.198],[0.346,0.061,0.058],[0.431,0.370,0.342],[0.736,0.521,0.508],[0.015,0.017,0.153],[0.019,0.022,0.020],[0.483,0.584,0.503],[0.513,0.477,0.626],[0.321,0.161,0.174],[0.191,0.199,0.349],[0.584,0.583,0.615],[0.871,0.691,0.918],[0.802,1.017,0.615],[0.377,0.367,0.461],[1.725,1.620,1.581],[1.073,1.276,1.210],[3.562,2.763,3.160],[0.104,0.009,0.007],[3.459,0.377,0.622],[0.737,0.856,0.099],[0.859,0.438,3.348],[0.560,0.531,0.533],[0.239,0.270,0.238],[0.203,0.153,0.151],[0.275,0.256,0.218],[0.798,0.642,0.614],[7.257,10.627,8.202],[0.049,0.043,0.044],[0.839,0.511,0.492],[0.679,0.650,1.909],[2.341,2.289,2.577],[2.289,2.249,2.351],[2.528,2.280,2.349],[0.308,0.368,0.394],[0.081,0.199,0.070],[0.042,0.044,0.048],[0.044,0.187,0.042],[0.117,0.282,0.115],[0.324,0.030,0.023],[0.024,0.025,0.275],[0.020,0.016,0.020]],"source":"clickhouse-cloud/results/gcp.2.64.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":624.235,"data_size":9946472478,"result":[[0.002,0.003,0.003],[0.436,0.101,0.027],[0.489,0.485,0.453],[0.932,0.638,0.509],[2.048,1.976,3.277],[5.523,4.064,4.729],[0.036,0.297,0.046],[0.031,0.029,0.124],[4.031,3.983,3.735],[5.097,4.084,5.364],[0.892,1.071,1.015],[1.369,1.248,1.048],[5.071,3.789,3.188],[8.329,5.543,5.561],[7.926,7.850,6.558],[3.138,4.210,3.896],[22.415,19.156,15.050],[12.186,13.088,12.221],[38.042,31.820,33.293],[0.083,0.356,0.010],[26.472,4.850,1.936],[5.362,6.587,0.535],[25.827,6.443,3.508],[44.375,2.833,2.906],[1.655,1.515,1.658],[1.069,0.972,1.079],[1.408,1.446,1.447],[4.730,5.520,5.878],[81.599,66.310,57.415],[0.159,0.150,0.325],[3.321,4.205,3.137],[4.248,11.743,4.316],[31.036,33.499,35.478],[24.170,24.829,28.875],[29.419,23.913,23.106],[1.865,1.767,1.752],[0.212,0.201,0.216],[0.079,0.074,0.080],[0.066,0.137,0.077],[0.371,0.366,0.356],[0.040,0.251,0.033],[0.027,0.031,0.031],[0.367,0.026,0.031]],"source":"clickhouse-cloud/results/gcp.2.8.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":405.591,"data_size":9941059364,"result":[[0.002,0.004,0.002],[0.072,0.044,0.438],[0.570,0.308,0.329],[0.770,0.800,0.174],[1.191,1.154,1.158],[3.630,2.398,2.141],[0.224,0.160,0.032],[0.311,0.028,0.075],[3.149,1.821,2.775],[3.248,3.173,2.034],[0.631,0.588,0.666],[0.761,0.855,0.666],[2.281,1.992,2.990],[3.517,4.857,3.004],[3.430,2.453,3.027],[1.541,1.601,1.625],[7.305,11.478,7.198],[4.711,4.874,7.611],[25.300,20.041,19.360],[0.059,0.008,0.256],[15.582,15.546,1.313],[3.434,5.248,0.456],[6.172,2.883,16.479],[5.965,39.976,2.742],[1.416,0.872,1.616],[0.651,1.046,0.633],[1.003,1.135,0.932],[3.397,17.229,2.984],[46.843,37.109,37.409],[0.271,0.199,0.143],[2.796,1.948,3.590],[2.733,6.833,2.480],[25.881,18.794,19.631],[29.379,16.171,15.171],[16.513,15.164,15.415],[1.243,1.353,1.336],[0.320,0.216,0.133],[0.327,0.198,0.059],[0.054,0.176,0.116],[0.382,0.218,0.616],[0.028,0.377,0.027],[0.028,0.026,0.283],[0.241,0.021,0.226]],"source":"clickhouse-cloud/results/gcp.3.12.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":74.495,"data_size":9951313728,"result":[[0.002,0.002,0.003],[0.260,0.212,0.086],[0.338,0.034,0.034],[0.283,0.250,0.044],[0.293,0.280,0.288],[0.611,0.487,0.315],[0.016,0.173,0.014],[0.146,0.017,0.019],[0.361,0.548,0.345],[0.494,0.337,0.343],[0.372,0.179,0.276],[0.190,0.384,0.200],[0.409,0.401,0.298],[0.539,0.528,0.564],[0.672,0.489,0.603],[0.363,0.344,0.334],[1.301,1.218,1.057],[0.781,0.762,0.830],[2.401,1.962,1.989],[0.222,0.007,0.056],[2.114,0.226,0.450],[1.404,0.083,0.477],[1.864,0.289,0.582],[54.808,0.418,0.470],[0.187,0.177,0.166],[0.115,0.122,0.112],[0.151,0.203,0.182],[0.612,0.438,0.530],[5.579,4.208,4.637],[0.268,0.038,0.041],[0.370,0.546,0.320],[1.095,0.762,0.462],[1.974,2.294,2.405],[1.426,1.499,1.473],[1.377,1.533,1.609],[0.276,0.267,0.273],[0.194,0.055,0.050],[0.034,0.033,0.034],[0.194,0.174,0.039],[0.469,0.089,0.191],[0.024,0.025,0.025],[0.297,0.246,0.019],[0.015,0.016,0.015]],"source":"clickhouse-cloud/results/gcp.3.120.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":289.010,"data_size":9940233961,"result":[[0.003,0.002,0.002],[0.418,0.047,0.020],[0.768,0.094,0.145],[0.176,0.536,0.135],[1.409,0.895,1.211],[1.706,2.317,1.387],[0.259,0.026,0.028],[0.145,0.024,0.097],[1.574,1.998,1.317],[1.803,1.815,1.830],[0.509,0.420,0.365],[0.553,0.585,0.552],[1.814,1.465,1.562],[2.518,2.579,2.342],[2.719,2.288,2.497],[1.682,1.743,1.348],[5.404,5.392,5.446],[4.976,4.958,4.485],[25.972,11.300,14.393],[0.189,0.049,0.010],[3.049,12.080,10.412],[3.804,2.690,2.598],[12.115,11.605,1.501],[38.233,2.040,1.748],[0.992,0.712,0.967],[0.511,0.556,0.484],[0.932,0.732,0.727],[2.444,2.850,2.374],[35.531,35.676,35.776],[0.260,0.172,0.088],[3.061,1.413,1.425],[6.371,2.396,4.461],[14.069,14.367,13.138],[17.469,10.930,6.905],[7.328,19.402,7.051],[1.045,0.863,0.971],[0.100,0.110,0.409],[0.290,0.045,0.047],[0.050,0.200,0.051],[0.175,0.552,0.171],[0.025,0.026,0.256],[0.237,0.139,0.026],[0.346,0.105,0.021]],"source":"clickhouse-cloud/results/gcp.3.16.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 236GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":89.672,"data_size":9950396333,"result":[[0.003,0.002,0.003],[0.302,0.032,0.029],[0.347,0.038,0.028],[0.323,0.050,0.044],[0.324,0.245,0.372],[0.489,0.244,0.242],[0.165,0.017,0.025],[0.110,0.029,0.027],[0.449,0.422,0.415],[0.818,0.502,0.559],[0.435,0.163,0.150],[0.429,0.152,0.154],[0.389,0.329,0.333],[0.388,0.682,0.538],[0.514,0.383,0.637],[0.245,0.194,0.898],[0.643,0.605,0.603],[0.389,0.371,0.418],[1.273,1.812,1.164],[0.023,0.205,0.006],[1.282,0.268,0.885],[0.336,0.073,0.344],[1.133,0.797,0.374],[0.381,46.595,0.355],[0.141,0.127,0.140],[0.098,0.099,0.119],[0.129,0.125,0.111],[0.418,0.350,0.535],[3.007,2.885,2.360],[0.296,0.049,0.065],[0.306,0.591,0.269],[0.901,0.401,0.427],[1.135,1.138,1.329],[1.202,1.120,1.046],[1.312,1.408,1.113],[0.309,0.146,0.134],[0.306,0.073,0.051],[0.043,0.045,0.046],[0.201,0.160,0.041],[0.174,0.252,0.124],[0.296,0.223,0.035],[0.180,0.020,0.206],[0.019,0.021,0.017]],"source":"clickhouse-cloud/results/gcp.3.236.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":158.944,"data_size":9943604442,"result":[[0.015,0.003,0.002],[1.367,0.110,0.061],[1.061,0.797,0.064],[0.699,0.456,0.129],[0.545,1.126,1.145],[1.443,1.110,0.928],[0.019,0.153,0.096],[0.184,0.021,0.119],[1.062,1.084,1.059],[1.316,0.775,0.734],[0.306,0.375,0.237],[0.344,0.271,0.257],[0.809,0.972,1.071],[1.767,1.199,1.315],[1.288,1.160,1.190],[1.122,0.929,0.658],[2.645,2.483,3.249],[2.781,1.813,2.022],[5.783,4.576,6.655],[0.159,0.039,0.008],[1.538,6.314,4.147],[1.347,1.558,0.198],[6.502,3.998,0.757],[1.159,43.459,0.949],[0.458,0.491,0.379],[0.301,0.276,0.281],[0.474,0.380,0.397],[1.274,1.305,1.413],[17.438,17.983,16.878],[0.080,0.206,0.057],[1.217,0.738,0.802],[2.886,1.920,1.144],[5.442,4.162,7.879],[8.185,4.096,7.535],[4.274,3.985,4.120],[0.837,0.535,0.731],[0.472,0.204,0.072],[0.257,0.213,0.043],[0.222,0.117,0.041],[0.402,0.098,0.115],[0.340,0.023,0.130],[0.021,0.293,0.025],[0.204,0.026,0.022]],"source":"clickhouse-cloud/results/gcp.3.32.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":86.005,"data_size":9946960904,"result":[[0.002,0.004,0.002],[0.337,0.092,0.018],[0.360,0.047,0.046],[0.358,0.061,0.054],[0.428,0.287,0.383],[0.692,0.594,0.456],[0.190,0.110,0.016],[0.113,0.014,0.148],[0.522,0.492,0.392],[0.826,0.669,0.577],[0.201,0.301,0.264],[0.314,0.252,0.206],[0.530,0.505,0.462],[0.666,0.629,0.672],[0.911,0.837,0.804],[0.437,0.378,0.445],[1.485,1.446,1.347],[0.963,0.996,0.930],[3.494,2.771,3.557],[0.029,0.008,0.101],[3.047,1.836,0.337],[0.808,0.785,0.761],[3.236,2.089,0.450],[39.098,36.014,0.565],[0.270,0.229,0.228],[0.181,0.168,0.169],[0.223,0.228,0.248],[0.757,0.703,0.672],[9.304,9.021,7.696],[0.048,0.054,0.049],[0.760,0.670,0.538],[1.664,0.631,0.571],[3.626,2.194,2.235],[2.270,2.223,2.097],[2.225,2.418,2.101],[0.335,0.726,0.489],[0.654,0.076,0.227],[0.042,0.368,0.155],[0.046,0.039,0.181],[0.102,0.404,0.107],[0.196,0.025,0.025],[0.236,0.023,0.107],[0.020,0.314,0.018]],"source":"clickhouse-cloud/results/gcp.3.64.json"}
-,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-09","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":627.889,"data_size":9944531331,"result":[[0.003,0.027,0.003],[0.499,0.648,0.047],[0.656,0.421,0.266],[1.187,1.054,0.926],[2.038,1.921,2.222],[8.109,7.408,4.338],[0.089,0.069,0.372],[0.138,0.135,0.073],[3.636,3.857,2.122],[3.961,6.220,5.082],[1.130,0.838,0.596],[1.254,1.031,1.062],[5.513,3.315,5.279],[8.276,14.217,5.993],[8.192,4.377,3.542],[2.382,3.180,4.134],[27.931,12.923,17.821],[13.417,14.065,13.347],[30.178,45.897,26.614],[0.136,0.237,0.197],[25.375,1.892,26.070],[6.361,0.609,0.598],[7.233,3.164,3.175],[46.341,41.990,6.414],[1.914,1.590,1.701],[0.911,1.051,1.007],[1.318,1.469,1.352],[4.979,4.183,5.651],[71.634,89.189,71.953],[0.318,0.238,0.146],[3.571,3.174,4.206],[4.594,10.857,11.199],[33.915,33.476,31.702],[26.368,21.748,21.364],[24.940,22.117,25.403],[1.635,1.596,1.649],[0.320,0.224,0.180],[0.074,0.345,0.196],[0.124,0.085,0.067],[0.308,0.463,0.386],[0.209,0.040,0.177],[0.159,0.024,0.210],[0.027,0.030,0.022]],"source":"clickhouse-cloud/results/gcp.3.8.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.499,0.035,0.038],[1.19,0.066,0.063],[1.592,0.129,0.128],[1.613,0.113,0.144],[0.597,0.605,0.604],[1.018,0.904,0.922],[1.269,0.067,0.068],[0.069,0.068,0.068],[1.372,0.707,0.703],[0.933,0.875,0.874],[0.351,0.267,0.266],[0.394,0.304,0.301],[0.922,0.93,0.917],[1.406,1.392,1.353],[1.09,1.086,1.082],[0.73,0.728,0.732],[2.689,2.709,2.695],[1.756,1.76,1.748],[5.85,4.98,4.971],[0.128,0.107,0.107],[4.993,1.216,1.211],[2.282,1.456,1.457],[8.032,3.743,2.739],[18.691,17.494,17.781],[1.612,0.52,0.523],[0.346,0.345,0.353],[0.526,0.52,0.52],[3.991,1.493,1.466],[11.167,10.519,10.505],[0.951,0.099,0.095],[2.74,1.007,0.984],[3.205,1.357,1.346],[12.518,15.834,13.179],[5.396,4.231,4.374],[4.239,4.354,10.651],[0.683,0.438,0.434],[0.339,0.146,0.148],[0.209,0.09,0.093],[0.13,0.071,0.076],[0.336,0.213,0.221],[0.129,0.061,0.058],[0.082,0.055,0.054],[0.053,0.05,0.051]],"source":"clickhouse-datalake-partitioned/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.69,0.041,0.036],[2.096,0.057,0.059],[2.114,0.105,0.107],[2.146,0.116,0.118],[0.435,0.437,0.433],[0.822,0.569,0.548],[0.846,0.069,0.059],[0.056,0.064,0.057],[0.847,0.53,0.557],[0.7,0.645,0.644],[0.301,0.233,0.226],[0.273,0.229,0.241],[0.703,0.681,0.688],[0.993,0.956,0.975],[0.787,0.764,0.76],[0.518,0.583,0.643],[2.524,2.183,2.194],[1.576,1.387,1.621],[4.876,4.279,4.011],[0.12,0.115,0.112],[5.05,1.223,1.191],[1.556,1.502,1.496],[4.898,3.176,3.287],[10.31,5.834,2.829],[0.384,0.373,0.377],[0.275,0.275,0.299],[0.376,0.384,0.389],[1.63,1.618,1.672],[5.459,5.483,5.585],[0.12,0.077,0.085],[0.628,0.639,0.631],[1.025,1.037,1.048],[4.823,4.767,4.65],[3.146,3.103,3.145],[3.048,3.122,3.05],[0.368,0.37,0.36],[0.147,0.181,0.156],[0.094,0.098,0.103],[0.084,0.087,0.086],[0.22,0.217,0.21],[0.057,0.071,0.066],[0.068,0.057,0.062],[0.058,0.061,0.052]],"source":"clickhouse-datalake-partitioned/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[1.223,0.052,0.055],[3.46,0.141,0.138],[5.261,0.377,0.392],[4.636,0.269,0.276],[1.803,1.813,1.848],[3.958,3.215,3.208],[3.966,0.149,0.153],[0.428,0.143,0.148],[5.028,2.323,2.327],[3.746,2.928,2.914],[1.345,0.846,0.843],[1.379,0.978,0.983],[3.262,3.159,3.11],[7.373,7.333,7.337],[4.015,6.697,3.859],[1.979,1.975,1.98],[12.878,12.678,12.934],[9.505,9.692,9.65],[32.379,29.486,32.324],[0.259,0.238,0.249],[18.713,16.341,15.024],[19.241,18.644,18.038],[39.48,39.202,39.495],[83.009,83.122,83.157],[10.552,3.413,1.879],[1.247,1.259,1.246],[1.862,1.904,1.888],[21.258,18.456,17.683],[48.135,45.929,44.736],[4.837,0.234,0.233],[15.302,9.027,3.802],[18.171,13.416,13.323],[null,null,null],[165.402,null,null],[null,302.897,null],[9.88,1.345,1.607],[0.82,0.291,0.281],[0.366,0.164,0.163],[0.464,0.118,0.117],[0.715,0.454,0.428],[0.314,0.093,0.091],[0.152,0.084,0.088],[0.085,0.08,0.082]],"source":"clickhouse-datalake-partitioned/results/c6a.large.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.142,0.067,0.07],[0.285,0.086,0.086],[0.377,0.126,0.108],[0.357,0.117,0.117],[0.282,0.298,0.284],[0.403,0.285,0.287],[0.35,0.082,0.091],[0.095,0.092,0.09],[0.574,0.398,0.399],[0.535,0.416,0.491],[0.257,0.207,0.217],[0.262,0.201,0.205],[0.28,0.299,0.262],[0.301,0.316,0.325],[0.344,0.294,0.286],[0.245,0.219,0.218],[0.504,0.513,0.539],[0.428,0.449,0.44],[1.162,0.862,0.882],[0.127,0.119,0.12],[2.16,0.428,0.476],[0.515,0.518,0.497],[1.853,0.652,0.719],[6.098,0.764,0.846],[0.2,0.19,0.187],[0.166,0.186,0.159],[0.193,0.177,0.196],[0.572,0.55,0.612],[1.448,1.478,1.441],[0.133,0.112,0.129],[0.255,0.249,0.228],[0.308,0.346,0.32],[1.314,1.187,1.206],[0.846,0.903,0.784],[0.862,0.797,0.767],[0.194,0.171,0.201],[0.184,0.187,0.178],[0.141,0.145,0.142],[0.102,0.107,0.122],[0.196,0.221,0.201],[0.101,0.106,0.099],[0.093,0.093,0.093],[0.092,0.092,0.093]],"source":"clickhouse-datalake-partitioned/results/c6a.metal.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.633,0.039,0.038],[1.873,0.084,0.083],[2.922,0.202,0.199],[2.398,0.15,0.15],[0.926,0.935,0.933],[1.81,1.61,1.612],[2.177,0.089,0.088],[0.088,0.088,0.087],[2.59,1.228,1.236],[1.721,1.53,1.529],[0.661,0.45,0.447],[0.7,0.518,0.513],[1.644,1.644,1.657],[2.442,2.451,2.463],[1.916,1.844,1.853],[1.046,1.054,1.06],[6.699,6.611,6.71],[4.988,5.103,5.167],[15.564,13.535,13.685],[0.138,0.139,0.146],[10.39,8.881,8.426],[8.755,5.526,2.763],[16.43,16.362,16.516],[42.21,40.341,39.985],[4.43,0.949,0.952],[0.627,0.628,0.633],[0.953,0.952,0.953],[9.755,6.945,4.336],[22.657,21.499,20.574],[2.29,0.137,0.136],[7.305,1.798,1.79],[7.309,4.809,2.645],[38.29,22.414,28.104],[18.571,19.012,27.018],[22.349,16.614,20.563],[2.408,0.837,0.841],[0.412,0.173,0.16],[0.197,0.095,0.113],[0.11,0.077,0.08],[0.422,0.259,0.248],[0.154,0.064,0.068],[0.083,0.056,0.059],[0.058,0.057,0.054]],"source":"clickhouse-datalake-partitioned/results/c6a.xlarge.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.527,0.086,0.076],[1.148,0.103,0.096],[1.318,0.121,0.131],[1.294,0.116,0.125],[0.46,0.441,0.44],[1.242,0.47,0.464],[0.652,0.095,0.095],[0.102,0.103,0.108],[0.847,0.409,0.403],[0.585,0.417,0.424],[0.379,0.224,0.225],[0.295,0.207,0.235],[0.299,0.299,0.267],[0.324,0.339,0.384],[0.295,0.285,0.275],[0.226,0.243,0.214],[0.461,0.389,0.398],[0.363,0.381,0.416],[1.609,0.791,0.802],[0.123,0.118,0.116],[5.569,0.45,0.395],[0.847,0.476,0.485],[2.786,0.586,0.584],[8.015,0.95,0.76],[0.193,0.225,0.206],[0.188,0.185,0.18],[0.197,0.199,0.185],[0.489,0.571,0.494],[1.153,1.249,1.197],[0.137,0.144,0.15],[0.258,0.245,0.244],[0.345,0.278,0.284],[0.915,0.886,0.982],[0.689,0.672,0.701],[0.699,0.736,0.776],[0.213,0.203,0.213],[0.177,0.193,0.18],[0.153,0.141,0.153],[0.138,0.118,0.117],[0.208,0.212,0.2],[0.124,0.112,0.121],[0.122,0.108,0.123],[0.105,0.099,0.103]],"source":"clickhouse-datalake-partitioned/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-28","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[1.104,0.032,0.039],[2.845,0.047,0.065],[2.511,0.081,0.081],[1.616,0.069,0.072],[0.215,0.209,0.204],[1.139,0.356,0.367],[0.845,0.05,0.047],[0.055,0.054,0.053],[0.781,0.273,0.274],[0.411,0.345,0.362],[0.265,0.156,0.163],[0.268,0.177,0.173],[0.361,0.358,0.366],[0.502,0.52,0.502],[0.437,0.405,0.408],[0.241,0.245,0.245],[0.884,0.811,0.927],[0.675,0.672,0.575],[3.231,1.571,1.58],[0.067,0.06,0.061],[4.003,0.483,0.468],[0.813,0.623,0.655],[3.626,0.996,1.017],[12.226,4.85,1.283],[0.232,0.221,0.224],[0.165,0.161,0.166],[0.228,0.22,0.228],[0.53,0.491,0.509],[2.955,2.981,2.928],[0.086,0.075,0.067],[0.373,0.366,0.366],[0.489,0.489,0.488],[1.67,1.661,1.677],[1.275,1.295,1.287],[1.309,1.323,1.299],[0.195,0.203,0.206],[0.115,0.116,0.105],[0.085,0.076,0.086],[0.077,0.08,0.062],[0.151,0.158,0.157],[0.064,0.071,0.051],[0.057,0.05,0.056],[0.052,0.053,0.064]],"source":"clickhouse-datalake-partitioned/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-28","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.287,0.062,0.063],[0.644,0.08,0.083],[1.412,0.087,0.089],[1.334,0.095,0.087],[0.367,0.324,0.282],[1.012,0.302,0.274],[0.55,0.065,0.069],[0.074,0.092,0.082],[0.516,0.294,0.281],[0.551,0.309,0.337],[0.229,0.162,0.162],[0.249,0.135,0.156],[0.224,0.232,0.219],[0.237,0.243,0.233],[0.238,0.206,0.241],[0.16,0.15,0.164],[0.388,0.333,0.392],[0.294,0.378,0.312],[1.451,0.657,0.591],[0.089,0.082,0.083],[5.35,0.381,0.384],[1.023,0.418,0.416],[3.187,0.642,0.668],[9.768,0.946,0.818],[0.151,0.166,0.152],[0.136,0.144,0.145],[0.148,0.144,0.167],[0.42,0.511,0.465],[1.366,1.232,1.224],[0.13,0.135,0.142],[0.196,0.199,0.209],[0.268,0.232,0.261],[0.775,0.768,0.929],[0.641,0.548,0.54],[0.581,0.581,0.637],[0.148,0.143,0.132],[0.139,0.139,0.141],[0.108,0.12,0.123],[0.099,0.099,0.103],[0.189,0.159,0.188],[0.09,0.082,0.088],[0.085,0.088,0.081],[0.088,0.074,0.077]],"source":"clickhouse-datalake-partitioned/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":323.710,"data_size":9941187008,"result":[[0.003,0.002,0.025],[0.047,0.046,0.059],[0.276,0.263,0.327],[0.467,0.426,0.512],[1.550,1.792,1.355],[2.510,2.335,2.162],[0.054,0.052,0.053],[0.027,0.025,0.026],[2.510,1.928,1.827],[2.413,2.248,2.321],[0.618,0.627,0.606],[0.729,0.721,0.771],[2.230,2.288,2.106],[4.107,3.936,4.127],[2.968,2.641,2.790],[1.505,1.545,1.330],[13.840,13.724,6.559],[8.126,8.211,8.052],[18.956,19.514,18.409],[0.062,0.008,0.008],[4.618,1.953,1.892],[5.011,0.424,0.418],[6.048,2.744,2.905],[2.713,2.402,2.365],[1.311,1.260,1.198],[0.946,0.850,0.817],[1.248,1.201,1.267],[4.306,4.484,4.588],[27.451,26.945,26.861],[0.117,0.113,0.112],[1.903,1.831,1.778],[2.376,2.233,2.244],[15.184,14.457,14.398],[13.427,14.808,14.618],[13.467,13.526,14.503],[0.783,0.719,0.723],[0.106,0.098,0.093],[0.054,0.049,0.048],[0.047,0.043,0.043],[0.197,0.180,0.189],[0.028,0.026,0.026],[0.024,0.025,0.025],[0.021,0.019,0.018]],"source":"clickhouse-cloud/results/aws.1.12.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":481.075,"data_size":9946730075,"result":[[0.003,0.006,0.010],[0.031,0.037,0.054],[0.401,0.316,0.343],[0.710,0.614,0.746],[3.500,3.816,3.350],[5.651,5.606,5.733],[0.137,0.119,0.108],[0.075,0.052,0.066],[4.382,3.840,3.526],[3.878,3.996,3.937],[1.120,1.040,1.022],[1.317,1.316,1.331],[4.182,4.354,3.622],[6.347,9.640,5.767],[4.511,4.372,4.292],[2.736,2.261,2.126],[15.895,16.684,16.645],[12.674,11.553,11.478],[30.414,20.126,20.310],[0.085,0.010,0.010],[5.041,2.232,1.991],[5.272,0.435,0.440],[6.403,2.832,2.916],[2.744,2.642,2.629],[1.771,1.456,1.410],[0.920,0.933,0.947],[1.402,1.395,1.470],[4.582,4.571,4.655],[29.919,29.235,29.833],[0.180,0.161,0.161],[2.563,2.526,2.502],[3.440,3.313,3.149],[19.476,19.080,21.154],[20.943,19.548,20.723],[19.605,19.807,19.399],[1.011,0.970,0.948],[0.165,0.141,0.144],[0.059,0.060,0.062],[0.063,0.061,0.057],[0.261,0.286,0.280],[0.033,0.031,0.028],[0.026,0.026,0.025],[0.024,0.022,0.021]],"source":"clickhouse-cloud/results/aws.1.8.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":342.201,"data_size":9941192060,"result":[[0.005,0.002,0.003],[0.185,0.066,0.023],[0.227,0.150,0.112],[0.527,0.425,0.410],[1.840,2.017,1.633],[2.625,2.129,2.556],[0.127,0.049,0.049],[0.125,0.028,0.027],[1.964,1.920,1.924],[2.593,2.333,1.641],[0.688,0.531,0.694],[0.790,0.834,0.833],[1.722,1.593,2.448],[2.803,2.659,4.050],[3.029,2.316,2.923],[1.074,1.005,1.047],[7.753,12.223,5.431],[6.289,4.730,3.534],[19.110,20.447,14.302],[0.186,0.065,0.008],[11.733,1.492,4.979],[5.510,3.630,0.324],[12.055,2.194,6.188],[32.665,25.441,3.773],[1.058,0.955,0.968],[0.794,0.620,0.666],[0.953,0.954,0.931],[3.207,3.086,3.119],[20.190,26.822,19.900],[0.242,0.117,0.125],[1.806,1.870,2.345],[2.609,2.471,2.384],[22.610,18.281,15.892],[13.598,15.561,14.154],[14.749,15.019,15.643],[0.832,0.759,0.831],[0.109,0.105,0.106],[0.050,0.185,0.052],[0.049,0.080,0.048],[0.214,0.227,0.200],[0.030,0.029,0.029],[0.023,0.021,0.167],[0.038,0.023,0.020]],"source":"clickhouse-cloud/results/aws.2.12.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":57.855,"data_size":9950566306,"result":[[0.002,0.002,0.002],[0.337,0.055,0.051],[0.250,0.023,0.025],[0.204,0.036,0.036],[0.191,0.177,0.200],[0.259,0.393,0.266],[0.104,0.014,0.012],[0.015,0.019,0.016],[0.249,0.256,0.248],[0.504,0.306,0.292],[0.131,0.126,0.274],[0.301,0.129,0.131],[0.314,0.262,0.255],[0.389,0.389,0.431],[0.280,0.398,0.293],[0.178,0.215,0.184],[0.653,0.634,0.668],[0.474,0.438,0.459],[1.353,1.161,1.260],[0.016,0.069,0.006],[1.115,0.191,0.402],[0.451,0.418,0.065],[1.180,0.525,0.266],[0.841,0.398,34.621],[0.135,0.140,0.132],[0.101,0.101,0.101],[0.131,0.133,0.131],[0.394,0.386,0.407],[2.827,2.099,2.005],[0.035,0.034,0.034],[0.474,0.263,0.248],[0.946,0.384,0.349],[1.333,0.993,1.665],[1.107,1.038,1.047],[1.065,1.024,0.992],[0.153,0.135,0.118],[0.151,0.045,0.039],[0.025,0.029,0.027],[0.030,0.131,0.029],[0.076,0.176,0.074],[0.018,0.017,0.150],[0.018,0.155,0.016],[0.014,0.014,0.014]],"source":"clickhouse-cloud/results/aws.2.120.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":241.970,"data_size":9941576459,"result":[[0.002,0.002,0.008],[0.195,0.075,0.023],[0.142,0.294,0.116],[0.244,0.322,0.162],[0.773,0.776,1.233],[1.912,1.936,1.628],[0.105,0.041,0.042],[0.025,0.024,0.023],[1.279,1.443,1.230],[1.659,1.623,1.360],[0.473,0.372,0.457],[0.544,0.449,0.525],[1.580,1.267,1.220],[2.663,1.977,1.950],[1.597,1.403,1.942],[0.853,0.756,0.822],[3.621,3.223,3.199],[3.130,2.111,2.161],[11.201,9.342,13.720],[0.051,0.006,0.007],[3.361,8.649,1.073],[2.629,3.455,0.248],[3.981,9.791,2.126],[2.017,33.194,1.389],[0.929,0.714,0.956],[0.579,0.463,0.515],[0.718,0.960,0.892],[2.357,3.052,2.266],[19.539,18.399,14.595],[0.332,0.088,0.090],[1.336,1.306,1.290],[4.625,1.815,2.384],[10.782,11.921,10.513],[12.034,6.540,11.606],[6.185,10.571,6.578],[0.642,0.519,0.630],[0.089,0.291,0.079],[0.198,0.038,0.041],[0.043,0.041,0.045],[0.362,0.140,0.134],[0.022,0.023,0.023],[0.022,0.020,0.169],[0.152,0.018,0.016]],"source":"clickhouse-cloud/results/aws.2.16.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 236GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":55.033,"data_size":9952006393,"result":[[0.002,0.002,0.002],[0.339,0.016,0.047],[0.171,0.019,0.023],[0.199,0.026,0.153],[0.128,0.109,0.115],[0.169,0.365,0.177],[0.027,0.132,0.014],[0.095,0.017,0.016],[0.427,0.268,0.298],[0.374,0.326,0.321],[0.220,0.222,0.113],[0.098,0.237,0.111],[0.192,0.162,0.164],[0.421,0.231,0.280],[0.307,0.202,0.200],[0.126,0.093,0.102],[0.437,0.384,0.392],[0.334,0.296,0.303],[0.845,1.010,0.627],[0.015,0.005,0.070],[0.759,0.145,0.146],[0.288,0.046,0.270],[0.357,0.191,0.198],[34.433,0.311,0.301],[0.095,0.105,0.104],[0.082,0.078,0.078],[0.105,0.103,0.104],[0.273,0.290,0.265],[1.167,1.171,1.192],[0.040,0.038,0.039],[0.301,0.188,0.198],[0.840,0.251,0.226],[0.891,0.869,0.806],[0.769,0.668,0.710],[0.715,0.732,0.727],[0.069,0.063,0.071],[0.133,0.042,0.044],[0.225,0.030,0.031],[0.167,0.031,0.031],[0.230,0.080,0.083],[0.020,0.017,0.189],[0.017,0.017,0.132],[0.014,0.014,0.014]],"source":"clickhouse-cloud/results/aws.2.236.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":108.783,"data_size":9945888007,"result":[[0.002,0.002,0.002],[0.020,0.039,0.023],[0.394,0.087,0.069],[0.203,0.127,0.090],[0.507,0.464,0.619],[0.951,0.830,0.847],[0.069,0.025,0.025],[0.017,0.141,0.018],[0.640,0.528,0.544],[0.823,0.725,0.740],[0.262,0.233,0.236],[0.317,0.399,0.272],[0.690,0.749,0.718],[1.148,1.050,0.993],[0.943,0.875,0.718],[0.518,0.411,0.416],[2.281,1.879,2.283],[1.284,1.292,1.114],[3.601,3.001,3.032],[0.116,0.030,0.005],[3.432,1.420,0.659],[1.577,0.139,0.138],[4.771,1.826,0.770],[26.813,0.923,0.890],[0.363,0.383,0.396],[0.266,0.273,0.249],[0.363,0.370,0.412],[1.216,1.174,1.351],[10.132,7.337,7.258],[0.063,0.062,0.064],[0.793,0.845,0.824],[1.049,1.950,0.985],[3.651,2.804,2.849],[3.373,5.144,3.599],[3.317,3.154,3.284],[0.394,0.403,0.558],[0.190,0.050,0.049],[0.186,0.029,0.029],[0.031,0.031,0.027],[0.085,0.289,0.084],[0.166,0.017,0.017],[0.017,0.017,0.017],[0.016,0.189,0.015]],"source":"clickhouse-cloud/results/aws.2.32.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":59.532,"data_size":9945061817,"result":[[0.002,0.002,0.002],[0.013,0.370,0.011],[0.032,0.170,0.031],[0.049,0.048,0.048],[0.345,0.247,0.250],[0.481,0.418,0.426],[0.087,0.014,0.014],[0.013,0.085,0.015],[0.377,0.380,0.533],[0.418,0.422,0.402],[0.145,0.150,0.283],[0.167,0.272,0.170],[0.444,0.388,0.369],[0.598,0.560,0.559],[0.523,0.653,0.453],[0.262,0.225,0.258],[0.975,0.937,1.012],[0.624,0.645,0.706],[1.901,2.113,1.638],[0.019,0.063,0.005],[0.673,0.309,0.306],[2.077,0.930,0.083],[1.025,0.446,0.425],[36.165,0.539,0.530],[0.226,0.227,0.222],[0.142,0.150,0.140],[0.228,0.226,0.234],[0.651,0.648,0.632],[5.149,3.665,3.939],[0.042,0.041,0.040],[0.439,0.422,0.428],[1.329,0.549,0.551],[1.977,1.449,1.689],[1.749,1.709,1.799],[1.733,1.800,1.730],[0.172,0.197,0.233],[0.049,0.049,0.048],[0.173,0.031,0.029],[0.129,0.031,0.027],[0.080,0.151,0.313],[0.016,0.016,0.139],[0.138,0.017,0.016],[0.012,0.012,0.012]],"source":"clickhouse-cloud/results/aws.2.64.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":488.681,"data_size":9944094244,"result":[[0.058,0.002,0.002],[0.105,0.193,0.034],[0.249,0.288,0.234],[0.744,0.502,0.493],[2.480,2.673,2.871],[2.999,4.278,2.535],[0.162,0.073,0.074],[0.035,0.035,0.036],[2.205,3.487,3.358],[2.412,4.020,2.469],[0.822,1.149,0.712],[1.345,0.931,1.445],[2.443,4.451,2.469],[6.895,11.274,7.001],[4.911,4.542,3.154],[2.536,2.070,1.855],[10.438,10.569,17.996],[12.166,8.171,13.333],[22.298,20.549,19.819],[0.305,0.100,0.682],[5.270,2.275,17.234],[7.173,0.473,5.373],[6.426,18.090,2.914],[23.863,2.872,2.764],[1.431,1.430,1.400],[0.913,0.938,0.939],[1.430,1.424,1.559],[4.796,4.674,4.698],[30.262,29.987,40.632],[0.170,0.163,0.312],[3.356,2.714,2.487],[7.294,3.233,3.277],[20.398,22.083,25.590],[20.969,20.225,19.834],[19.962,20.493,20.046],[1.055,1.034,0.964],[0.163,0.156,0.167],[0.077,0.070,0.068],[0.072,0.064,0.063],[0.276,0.289,0.284],[0.034,0.032,0.032],[0.029,0.025,0.155],[0.026,0.025,0.023]],"source":"clickhouse-cloud/results/aws.2.8.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":318.314,"data_size":9941720438,"result":[[0.002,0.002,0.002],[0.352,0.029,0.412],[0.317,0.182,0.223],[0.365,0.624,0.229],[1.952,1.836,1.840],[2.976,2.061,2.422],[0.170,0.052,0.052],[0.083,0.059,0.027],[2.008,1.673,1.336],[2.284,2.412,2.015],[0.555,0.499,0.485],[0.639,0.663,0.585],[1.974,1.647,1.575],[2.652,2.357,2.712],[2.387,2.085,1.902],[1.636,1.298,1.508],[10.493,6.848,4.780],[5.555,3.321,4.734],[17.584,14.721,12.864],[0.208,0.007,0.007],[11.479,4.002,1.946],[5.117,0.397,0.397],[12.021,1.934,6.318],[35.288,30.907,28.896],[2.048,0.951,0.991],[0.759,0.619,0.617],[1.042,1.175,1.083],[3.419,3.104,8.707],[26.370,23.292,19.655],[0.129,0.260,0.112],[2.228,1.883,2.147],[2.582,4.933,4.402],[16.538,17.792,16.478],[13.981,14.522,13.424],[13.699,13.729,14.145],[0.759,0.861,0.745],[0.180,0.104,0.245],[0.051,0.189,0.136],[0.056,0.046,0.149],[0.284,0.289,0.198],[0.185,0.115,0.029],[0.134,0.024,0.024],[0.019,0.024,0.018]],"source":"clickhouse-cloud/results/aws.3.12.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":56.879,"data_size":9953034175,"result":[[0.002,0.002,0.002],[0.423,0.048,0.012],[0.023,0.024,0.495],[0.035,0.241,0.035],[0.267,0.178,0.204],[0.272,0.384,0.250],[0.013,0.093,0.013],[0.015,0.015,0.105],[0.400,0.305,0.229],[0.386,0.295,0.292],[0.129,0.130,0.235],[0.135,0.133,0.136],[0.267,0.257,0.395],[0.405,0.398,0.435],[0.436,0.404,0.303],[0.220,0.225,0.193],[0.653,0.666,0.655],[0.505,0.465,0.526],[1.210,1.049,1.430],[0.080,0.041,0.005],[1.114,0.383,0.208],[0.933,0.433,0.064],[1.217,0.823,0.270],[31.395,0.411,0.349],[0.137,0.132,0.131],[0.103,0.104,0.105],[0.134,0.134,0.136],[0.386,0.448,0.390],[2.728,2.362,2.022],[0.038,0.037,0.178],[0.271,0.435,0.265],[1.145,0.379,0.340],[1.314,1.821,1.780],[0.987,1.064,1.021],[1.059,1.066,1.008],[0.149,0.153,0.148],[0.039,0.150,0.138],[0.027,0.027,0.025],[0.112,0.029,0.029],[0.183,0.073,0.155],[0.017,0.130,0.105],[0.017,0.138,0.016],[0.013,0.012,0.014]],"source":"clickhouse-cloud/results/aws.3.120.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":234.822,"data_size":9940747153,"result":[[0.002,0.020,0.002],[0.043,0.271,0.018],[0.221,0.096,0.189],[0.247,0.223,0.368],[1.183,1.152,0.776],[1.587,1.392,1.195],[0.104,0.091,0.039],[0.068,0.056,0.022],[1.142,1.291,1.086],[1.196,1.268,1.176],[0.497,0.381,0.384],[0.534,0.447,0.500],[1.244,1.359,1.134],[2.565,1.851,1.877],[1.540,1.865,1.361],[0.829,1.110,0.733],[3.278,3.229,3.273],[3.033,2.288,2.912],[13.656,7.295,6.843],[0.145,0.099,0.006],[3.155,8.626,5.220],[3.353,0.265,2.676],[3.828,1.857,8.960],[1.878,27.744,16.678],[0.702,0.929,0.694],[0.458,0.569,0.549],[0.845,0.704,0.904],[2.388,2.302,2.981],[19.031,16.971,14.972],[0.232,0.087,0.087],[2.279,1.280,1.719],[1.970,3.463,2.814],[11.282,15.922,10.983],[11.263,10.164,5.881],[6.217,10.193,9.071],[0.605,0.617,0.611],[0.284,0.165,0.074],[0.193,0.041,0.099],[0.040,0.130,0.039],[0.313,0.217,0.130],[0.195,0.100,0.023],[0.173,0.021,0.021],[0.151,0.072,0.016]],"source":"clickhouse-cloud/results/aws.3.16.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 236GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":54.885,"data_size":9946053338,"result":[[0.002,0.002,0.002],[0.475,0.015,0.013],[0.186,0.264,0.022],[0.241,0.023,0.152],[0.119,0.125,0.109],[0.327,0.162,0.280],[0.115,0.093,0.013],[0.082,0.101,0.015],[0.436,0.315,0.390],[0.335,0.373,0.365],[0.207,0.177,0.099],[0.216,0.096,0.096],[0.197,0.166,0.310],[0.392,0.255,0.271],[0.315,0.195,0.204],[0.102,0.103,0.099],[0.427,0.361,0.370],[0.322,0.325,0.279],[0.931,0.902,0.600],[0.016,0.064,0.046],[0.756,0.247,0.140],[0.276,0.638,0.271],[0.831,0.192,0.564],[34.038,22.352,0.296],[0.106,0.099,0.097],[0.079,0.080,0.078],[0.103,0.102,0.100],[0.294,0.285,0.299],[1.623,1.198,1.163],[0.039,0.040,0.038],[0.341,0.199,0.250],[0.700,0.259,0.512],[1.064,1.064,0.892],[0.765,0.720,0.669],[0.672,0.758,0.713],[0.096,0.071,0.066],[0.038,0.040,0.159],[0.027,0.087,0.026],[0.026,0.138,0.026],[0.173,0.150,0.067],[0.151,0.115,0.016],[0.148,0.016,0.016],[0.013,0.185,0.013]],"source":"clickhouse-cloud/results/aws.3.236.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":106.068,"data_size":9946697448,"result":[[0.003,0.002,0.002],[0.358,0.017,0.015],[0.988,0.121,0.060],[0.188,0.184,0.086],[0.474,0.464,0.448],[1.078,0.877,0.787],[0.075,0.024,0.023],[0.017,0.016,0.187],[0.646,0.634,0.520],[0.697,0.689,0.652],[0.291,0.223,0.225],[0.359,0.368,0.242],[0.689,0.759,0.720],[1.316,1.107,1.108],[0.929,0.855,0.735],[0.529,0.588,0.406],[2.253,1.872,1.796],[1.241,1.159,1.159],[3.463,2.932,3.583],[0.078,0.027,0.005],[1.372,0.638,0.626],[1.639,0.135,0.138],[1.787,0.837,6.683],[0.935,0.879,34.962],[0.404,0.387,0.398],[0.251,0.242,0.278],[0.371,0.409,0.370],[1.192,1.153,1.405],[8.235,8.221,10.347],[0.062,0.154,0.061],[0.940,0.778,0.701],[2.088,1.077,0.920],[4.657,3.148,4.388],[3.182,3.580,3.166],[4.051,3.617,3.147],[0.359,0.383,0.341],[0.209,0.088,0.055],[0.226,0.032,0.034],[0.139,0.030,0.033],[0.382,0.098,0.092],[0.124,0.136,0.019],[0.127,0.085,0.018],[0.014,0.014,0.015]],"source":"clickhouse-cloud/results/aws.3.32.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":60.660,"data_size":9945707348,"result":[[0.002,0.002,0.002],[0.428,0.046,0.011],[0.170,0.033,0.032],[0.051,0.234,0.116],[0.237,0.219,0.245],[0.544,0.495,0.403],[0.015,0.131,0.098],[0.014,0.014,0.080],[0.329,0.528,0.432],[0.418,0.410,0.490],[0.239,0.137,0.135],[0.254,0.167,0.166],[0.385,0.388,0.513],[0.604,0.599,0.571],[0.579,0.598,0.438],[0.245,0.216,0.235],[1.150,1.023,1.036],[0.633,0.798,0.621],[1.936,1.702,1.750],[0.018,0.096,0.005],[1.772,0.315,1.460],[0.723,0.781,0.081],[2.210,0.890,0.434],[32.229,19.182,0.520],[0.304,0.197,0.211],[0.146,0.146,0.138],[0.197,0.216,0.204],[0.650,0.654,0.672],[5.333,3.668,3.712],[0.041,0.043,0.042],[0.634,0.481,0.420],[0.546,1.185,0.570],[1.592,2.445,1.583],[1.694,1.881,1.693],[1.702,3.028,1.675],[0.482,0.260,0.189],[0.237,0.223,0.038],[0.148,0.026,0.026],[0.112,0.029,0.112],[0.280,0.065,0.066],[0.190,0.108,0.017],[0.107,0.016,0.016],[0.116,0.013,0.100]],"source":"clickhouse-cloud/results/aws.3.64.json"}
+,{"system":"ClickHouse ☁️ (aws)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","aws"],"load_time":504.274,"data_size":9946970982,"result":[[0.004,0.002,0.002],[0.434,0.157,0.082],[0.405,0.198,0.492],[0.733,0.807,0.875],[1.852,1.532,1.581],[3.210,6.363,2.596],[0.158,0.119,0.115],[0.065,0.212,0.036],[3.943,3.358,2.490],[2.869,3.810,2.491],[1.116,1.045,1.077],[0.988,0.859,0.860],[2.836,3.790,4.454],[4.393,6.675,10.086],[3.540,3.034,3.106],[1.587,3.012,1.351],[10.280,18.004,7.166],[8.221,8.977,9.611],[22.126,21.884,20.448],[0.227,0.011,0.179],[18.561,5.107,2.145],[5.674,0.484,5.398],[6.374,24.649,2.929],[36.631,2.908,33.245],[1.533,1.423,1.376],[0.919,0.915,0.920],[1.415,1.418,1.462],[4.938,5.044,4.542],[39.943,29.982,29.715],[0.169,0.366,0.163],[3.223,2.564,2.525],[7.404,3.758,3.023],[30.656,25.630,23.483],[23.588,20.852,20.760],[21.335,21.764,21.588],[1.054,0.984,1.013],[0.155,0.156,0.162],[0.243,0.068,0.069],[0.061,0.060,0.065],[0.308,0.265,0.285],[0.035,0.201,0.033],[0.073,0.027,0.027],[0.026,0.023,0.022]],"source":"clickhouse-cloud/results/aws.3.8.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":459.206,"data_size":9940768043,"result":[[0.003,0.002,0.002],[0.054,0.062,0.017],[0.301,0.229,0.307],[0.414,0.308,0.297],[1.921,1.643,1.761],[2.919,2.938,3.007],[0.028,0.024,0.028],[0.026,0.022,0.024],[2.462,2.880,2.525],[2.915,2.527,2.036],[0.450,0.490,0.502],[0.480,0.541,0.572],[2.081,2.246,2.237],[3.453,3.537,3.421],[2.915,3.521,2.870],[1.725,1.609,1.754],[14.296,7.582,9.847],[7.512,7.432,7.940],[21.050,19.225,18.630],[0.057,0.007,0.008],[4.002,1.700,1.687],[4.531,0.386,0.374],[5.660,2.476,2.363],[2.379,2.082,2.155],[1.134,1.056,1.067],[0.761,0.756,0.771],[1.092,1.082,1.135],[3.748,3.691,3.702],[26.901,26.683,27.861],[0.123,0.132,0.117],[2.356,2.150,2.431],[3.474,3.022,2.932],[19.787,20.005,18.940],[14.820,15.477,14.018],[13.003,12.845,12.943],[0.798,0.858,0.757],[0.092,0.107,0.109],[0.047,0.039,0.040],[0.051,0.039,0.037],[0.199,0.195,0.186],[0.025,0.023,0.027],[0.019,0.019,0.020],[0.017,0.014,0.014]],"source":"clickhouse-cloud/results/azure.1.12.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":486.540,"data_size":9941786960,"result":[[0.003,0.017,0.019],[0.038,0.020,0.019],[0.364,0.408,0.349],[0.608,0.508,0.602],[2.919,2.795,2.536],[3.549,3.355,3.265],[0.044,0.039,0.044],[0.026,0.026,0.025],[3.173,3.505,3.321],[3.881,3.838,3.481],[0.921,0.833,0.829],[0.956,1.006,0.996],[3.702,3.829,3.684],[5.630,9.233,5.971],[4.759,4.001,3.712],[2.702,2.405,2.693],[15.830,10.333,15.586],[10.787,10.984,11.865],[29.273,28.904,28.633],[0.121,0.007,0.007],[6.938,2.987,2.871],[7.589,0.686,0.643],[9.706,4.084,4.363],[4.019,3.965,4.059],[1.894,1.843,1.889],[1.218,1.340,1.377],[1.843,1.991,1.918],[6.714,6.711,6.714],[39.246,27.884,27.101],[0.153,0.148,0.151],[2.739,2.327,3.006],[3.216,2.876,3.026],[20.885,21.665,22.077],[20.327,20.482,19.892],[19.569,19.625,19.787],[1.100,0.988,0.967],[0.149,0.120,0.137],[0.060,0.051,0.058],[0.051,0.052,0.074],[0.258,0.258,0.217],[0.028,0.030,0.024],[0.020,0.019,0.018],[0.018,0.014,0.014]],"source":"clickhouse-cloud/results/azure.1.8.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":449.829,"data_size":9941231286,"result":[[0.003,0.005,0.003],[0.269,0.029,0.128],[0.291,0.111,0.182],[0.259,0.972,0.188],[1.217,1.188,1.146],[3.890,2.474,3.018],[0.049,0.027,0.033],[0.037,0.024,0.024],[2.265,2.762,1.858],[2.533,2.602,2.557],[0.583,0.486,0.519],[0.735,0.746,0.623],[2.620,2.026,2.198],[3.993,4.343,4.425],[3.511,3.073,2.733],[1.525,1.750,1.739],[7.884,5.904,6.939],[3.091,4.079,3.259],[21.088,20.284,18.680],[0.053,0.006,0.007],[3.020,4.526,1.294],[4.502,0.406,3.289],[5.746,3.963,2.483],[1.808,2.452,1.646],[0.876,1.030,0.877],[0.606,0.740,0.696],[1.132,0.862,1.143],[2.957,3.704,2.939],[19.115,27.734,19.106],[0.168,0.118,0.125],[2.779,2.492,1.877],[2.979,3.407,2.372],[21.379,17.276,20.156],[30.648,10.872,14.770],[13.721,18.370,16.858],[0.823,0.750,0.739],[0.105,0.149,0.094],[0.061,0.049,0.056],[0.047,0.042,0.042],[0.193,0.194,0.205],[0.026,0.023,0.026],[0.020,0.020,0.020],[0.016,0.013,0.013]],"source":"clickhouse-cloud/results/azure.2.12.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":80.247,"data_size":9951765184,"result":[[0.002,0.002,0.002],[0.025,0.247,0.017],[0.264,0.062,0.119],[0.813,0.138,0.039],[0.237,0.274,0.260],[0.865,0.315,0.308],[0.073,0.011,0.023],[0.026,0.014,0.012],[0.413,0.308,0.623],[0.342,0.333,0.395],[0.147,0.144,0.167],[0.159,0.210,0.141],[0.362,0.568,0.278],[0.391,0.408,0.387],[0.341,0.353,0.525],[0.268,0.418,0.252],[0.874,0.859,0.771],[0.554,0.556,0.548],[1.903,1.562,1.828],[0.017,0.006,0.036],[3.056,0.236,0.433],[0.509,0.074,0.503],[0.560,0.337,0.325],[23.387,0.459,0.409],[0.463,0.148,0.164],[0.130,0.124,0.107],[0.151,0.142,0.155],[0.507,0.447,0.496],[3.737,2.610,2.717],[0.045,0.039,0.037],[0.313,0.491,0.284],[0.511,2.454,0.412],[2.468,1.799,1.879],[1.286,1.402,1.392],[1.334,1.300,1.246],[0.195,0.164,0.136],[0.047,0.067,0.046],[0.087,0.026,0.028],[0.031,0.032,0.034],[0.099,0.082,0.083],[0.075,0.019,0.022],[0.018,0.018,0.015],[0.012,0.012,0.012]],"source":"clickhouse-cloud/results/azure.2.120.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":252.500,"data_size":9943052653,"result":[[0.003,0.002,0.002],[0.200,0.024,0.040],[0.293,0.141,0.092],[0.854,0.144,0.254],[1.058,1.209,1.559],[2.704,1.339,1.471],[0.088,0.027,0.026],[0.021,0.032,0.020],[1.862,2.115,1.295],[1.379,1.338,2.444],[0.547,0.359,0.570],[0.406,0.435,0.589],[1.380,1.648,1.335],[4.054,2.192,3.707],[2.758,2.465,1.563],[1.064,1.162,0.914],[4.393,5.490,3.744],[2.569,2.383,2.413],[11.693,17.596,9.588],[0.068,0.058,0.006],[3.396,1.493,6.704],[2.805,3.726,0.266],[4.350,4.711,1.482],[3.918,1.497,1.497],[0.960,0.860,0.847],[0.539,0.607,0.592],[0.657,0.881,0.650],[2.240,2.857,2.993],[13.249,19.119,18.186],[0.093,0.085,0.090],[1.264,1.708,1.890],[3.267,2.333,2.334],[14.141,13.162,18.945],[9.169,14.634,7.402],[11.149,19.186,11.356],[0.763,0.800,0.646],[0.082,0.116,0.088],[0.276,0.040,0.038],[0.046,0.037,0.043],[0.478,0.152,0.147],[0.023,0.240,0.023],[0.101,0.020,0.019],[0.014,0.012,0.018]],"source":"clickhouse-cloud/results/azure.2.16.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":134.425,"data_size":9947343498,"result":[[0.002,0.003,0.002],[0.033,0.351,0.018],[0.092,0.327,0.074],[0.137,0.677,0.136],[0.500,1.123,0.483],[1.444,1.242,1.033],[0.017,0.022,0.037],[0.017,0.038,0.017],[1.032,0.811,0.816],[0.714,0.653,0.772],[0.238,0.237,0.293],[0.326,0.298,0.212],[0.908,0.651,0.855],[1.370,1.050,1.337],[1.281,1.707,1.724],[0.710,0.432,0.795],[2.940,2.750,2.431],[1.449,1.630,1.014],[4.281,4.370,4.233],[0.045,0.005,0.028],[1.642,0.702,7.426],[1.669,0.167,1.342],[5.121,2.066,0.964],[0.955,0.885,19.302],[0.351,0.346,0.339],[0.228,0.321,0.294],[0.399,0.392,0.353],[1.273,1.124,1.550],[8.664,8.534,9.182],[0.066,0.064,0.055],[0.687,0.643,0.737],[1.113,2.180,1.095],[3.410,2.905,5.810],[4.495,4.091,4.281],[4.170,3.062,3.032],[0.418,0.312,0.527],[0.065,0.054,0.067],[0.036,0.037,0.029],[0.036,0.038,0.033],[0.143,0.138,0.133],[0.017,0.021,0.018],[0.020,0.018,0.018],[0.014,0.014,0.013]],"source":"clickhouse-cloud/results/azure.2.32.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":91.839,"data_size":9948366216,"result":[[0.002,0.004,0.002],[0.023,0.716,0.036],[0.329,0.034,0.034],[0.869,0.291,0.123],[0.455,0.422,0.390],[0.591,0.802,0.611],[0.027,0.015,0.019],[0.040,0.016,0.039],[0.529,0.538,0.591],[0.645,0.642,0.589],[0.286,0.500,0.176],[0.227,0.169,0.166],[0.562,0.563,0.596],[0.820,0.611,0.861],[0.549,0.459,0.478],[0.287,0.284,0.375],[1.390,1.523,0.981],[0.619,0.885,0.805],[2.592,3.311,1.998],[0.029,0.038,0.006],[0.877,4.544,1.122],[0.917,1.201,0.095],[3.447,0.450,1.025],[21.143,0.580,0.557],[0.214,0.214,0.224],[0.146,0.196,0.183],[0.214,0.226,0.226],[0.804,0.791,0.764],[5.325,5.469,5.377],[0.251,0.051,0.045],[1.014,0.534,0.486],[2.529,0.760,0.627],[2.207,2.198,3.610],[2.002,2.164,2.179],[2.611,1.965,1.885],[0.235,0.288,0.230],[0.053,0.058,0.049],[0.035,0.029,0.030],[0.028,0.029,0.030],[0.084,0.084,0.075],[0.029,0.018,0.038],[0.018,0.026,0.017],[0.016,0.014,0.010]],"source":"clickhouse-cloud/results/azure.2.64.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":484.910,"data_size":9944687072,"result":[[0.002,0.003,0.003],[0.226,0.025,0.020],[0.329,0.200,0.272],[0.546,0.477,0.520],[2.455,3.388,1.696],[2.776,5.207,4.959],[0.047,0.068,0.051],[0.030,0.029,0.032],[2.234,4.208,4.216],[4.807,3.751,4.011],[2.014,0.914,0.750],[0.951,0.902,1.091],[2.789,4.473,4.092],[4.190,6.660,10.524],[4.419,3.840,3.029],[2.100,2.196,1.911],[12.024,11.974,11.648],[7.711,6.628,7.940],[31.601,32.659,21.804],[0.113,1.290,0.008],[24.970,3.207,5.017],[5.201,0.467,7.635],[13.368,6.208,2.845],[4.996,2.743,2.465],[1.514,1.318,1.306],[0.866,0.985,0.931],[1.539,1.281,1.294],[4.454,4.463,4.274],[29.914,28.192,27.997],[0.148,0.162,0.149],[2.601,2.506,2.342],[4.324,3.425,3.800],[22.280,27.983,22.098],[21.342,22.652,20.576],[21.245,19.673,19.414],[1.129,1.150,0.978],[0.139,0.183,0.149],[0.061,0.062,0.057],[0.055,0.079,0.054],[0.265,0.264,0.275],[0.029,0.034,0.029],[0.024,0.022,0.022],[0.018,0.016,0.015]],"source":"clickhouse-cloud/results/azure.2.8.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":426.882,"data_size":9941423994,"result":[[0.003,0.002,0.004],[0.327,0.028,0.046],[0.312,0.428,0.266],[0.804,0.395,0.931],[2.506,1.263,1.952],[2.977,2.189,3.077],[0.097,0.028,0.042],[0.032,0.036,0.020],[1.613,1.450,1.475],[3.495,3.397,3.610],[0.701,0.554,0.533],[1.466,0.591,0.543],[2.877,2.279,4.412],[3.557,3.934,4.238],[3.668,3.012,2.445],[1.662,1.556,3.154],[16.166,5.510,7.772],[6.071,7.212,2.632],[20.849,12.534,11.951],[0.089,0.055,0.053],[3.080,4.285,1.259],[3.286,0.280,0.291],[4.007,5.652,2.349],[1.746,2.553,4.499],[1.095,1.055,0.869],[0.720,0.714,0.587],[1.033,0.857,0.816],[2.897,3.881,2.883],[23.551,17.791,23.816],[0.125,0.106,0.133],[1.642,2.619,2.819],[4.249,4.479,2.325],[40.314,44.658,19.269],[15.793,26.958,26.017],[19.537,21.073,20.026],[0.805,0.792,0.723],[0.152,0.100,0.090],[0.048,0.064,0.043],[0.059,0.056,0.041],[0.195,0.185,0.176],[0.041,0.034,0.024],[0.038,0.030,0.018],[0.015,0.012,0.013]],"source":"clickhouse-cloud/results/azure.3.12.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":72.354,"data_size":9951455295,"result":[[0.002,0.003,0.002],[0.314,0.016,0.025],[0.414,0.365,0.036],[0.040,0.418,0.411],[0.259,0.239,0.291],[0.320,0.305,1.030],[0.032,0.010,0.010],[0.017,0.014,0.013],[0.636,0.848,0.348],[0.607,0.340,0.323],[0.274,0.141,0.139],[0.144,0.160,0.150],[0.873,0.722,0.314],[0.459,0.530,0.417],[0.331,0.277,0.276],[0.384,0.245,0.224],[0.860,1.099,0.789],[0.497,0.660,0.517],[1.832,2.452,1.913],[0.024,0.006,0.044],[3.033,0.437,1.024],[0.901,0.100,0.095],[2.185,0.424,0.619],[0.414,25.933,0.413],[0.548,0.186,0.433],[0.115,0.138,0.114],[0.157,0.200,0.140],[0.492,0.462,0.483],[4.289,3.609,2.416],[0.256,0.036,0.035],[0.569,0.351,0.289],[2.003,0.452,0.400],[2.104,1.639,2.759],[1.465,1.270,1.556],[1.206,1.191,1.195],[0.170,0.138,0.129],[0.067,0.094,0.047],[0.045,0.028,0.028],[0.028,0.027,0.041],[0.115,0.071,0.068],[0.020,0.030,0.016],[0.015,0.016,0.022],[0.012,0.011,0.011]],"source":"clickhouse-cloud/results/azure.3.120.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":318.079,"data_size":9940963201,"result":[[0.003,0.003,0.003],[0.257,0.028,0.263],[0.209,0.448,0.202],[0.830,0.243,0.219],[1.531,1.712,1.112],[2.537,1.789,2.458],[0.085,0.025,0.042],[0.039,0.032,0.019],[1.464,1.419,1.348],[1.650,1.661,1.788],[2.163,0.329,0.341],[0.381,0.401,2.077],[1.350,3.762,1.454],[5.179,3.022,2.150],[1.735,3.935,1.503],[1.213,1.021,1.143],[4.707,9.512,4.589],[5.743,3.164,2.479],[14.185,7.695,8.486],[0.073,0.067,0.046],[6.923,3.609,1.329],[3.060,2.838,0.298],[5.331,2.777,3.186],[2.436,2.734,1.459],[0.675,0.671,0.693],[0.460,0.505,0.755],[1.166,1.174,0.653],[4.053,2.156,2.470],[15.610,14.953,24.080],[0.112,0.128,0.155],[1.473,2.764,1.298],[5.005,2.051,4.075],[31.682,27.905,29.703],[13.711,19.568,6.861],[10.966,6.824,11.459],[1.207,0.788,1.677],[0.437,0.339,0.084],[0.060,0.069,0.064],[0.112,0.046,0.094],[0.367,0.170,0.191],[0.028,0.025,0.190],[0.157,0.080,0.025],[0.025,0.021,0.043]],"source":"clickhouse-cloud/results/azure.3.16.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":118.507,"data_size":9945591763,"result":[[0.002,0.002,0.002],[0.021,0.357,0.432],[0.391,0.065,0.062],[1.039,0.075,0.894],[0.576,0.645,0.548],[1.396,0.818,0.804],[0.557,0.017,0.034],[0.045,0.015,0.014],[0.857,0.906,0.652],[1.193,0.852,0.954],[0.246,0.214,0.201],[0.234,0.277,0.240],[1.073,0.790,1.373],[1.225,1.185,1.095],[0.818,0.962,0.838],[0.784,0.693,0.655],[2.376,2.283,2.348],[1.856,1.359,1.071],[6.361,3.718,4.902],[0.060,0.005,0.029],[1.229,0.553,6.325],[7.855,1.369,1.544],[4.647,5.012,0.871],[14.071,5.591,0.778],[0.436,0.349,0.341],[0.248,0.249,0.244],[0.397,0.417,0.397],[1.355,1.183,1.184],[11.418,9.654,7.923],[0.063,0.074,0.059],[0.835,0.842,0.695],[0.972,0.897,0.991],[3.523,3.254,4.670],[3.549,3.242,3.498],[3.616,3.527,3.641],[0.426,0.469,0.430],[0.060,0.057,0.055],[0.033,0.034,0.031],[0.033,0.034,0.033],[0.098,0.108,0.105],[0.016,0.016,0.018],[0.015,0.016,0.017],[0.013,0.014,0.012]],"source":"clickhouse-cloud/results/azure.3.32.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":105.649,"data_size":9949909978,"result":[[0.002,0.002,0.008],[0.606,0.018,0.024],[0.239,0.036,0.041],[0.569,0.892,0.167],[0.296,0.590,0.352],[0.943,0.419,1.325],[0.018,0.020,0.017],[0.084,0.426,0.013],[0.570,0.708,0.667],[0.769,0.625,0.476],[0.250,0.189,0.272],[0.251,0.303,0.278],[0.618,0.417,0.538],[0.604,1.275,0.696],[2.948,0.448,0.934],[0.628,0.430,0.333],[1.208,2.391,2.093],[1.594,1.197,1.229],[2.652,4.536,3.945],[0.029,0.312,0.321],[4.031,0.871,3.961],[0.871,0.099,0.838],[2.729,1.492,0.453],[13.997,0.865,0.780],[0.290,0.224,0.286],[0.168,0.155,0.206],[0.219,0.682,0.229],[0.698,0.664,0.731],[5.697,5.985,4.036],[0.058,0.209,0.179],[0.552,0.760,0.412],[1.177,2.220,1.099],[4.937,3.265,4.514],[3.395,1.876,3.334],[1.965,3.160,2.036],[0.243,0.337,0.243],[0.052,0.041,0.099],[0.027,0.035,0.033],[0.029,0.049,0.045],[0.145,0.087,0.104],[0.018,0.030,0.020],[0.026,0.025,0.017],[0.011,0.013,0.017]],"source":"clickhouse-cloud/results/azure.3.64.json"}
+,{"system":"ClickHouse ☁️ (azure)","date":"2025-10-15","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","azure"],"load_time":575.200,"data_size":9943448014,"result":[[0.003,0.002,0.002],[0.268,0.021,0.240],[0.164,0.274,0.350],[4.691,0.317,0.279],[2.427,2.335,3.899],[3.811,6.432,2.465],[0.068,0.052,0.095],[0.037,0.032,0.029],[4.839,2.002,4.868],[2.320,4.301,2.338],[0.906,0.849,1.052],[1.269,0.740,0.753],[3.943,3.550,4.664],[6.904,8.887,3.948],[3.744,5.483,4.840],[2.051,2.271,3.731],[14.713,13.146,22.736],[15.506,9.447,11.290],[37.088,47.602,43.541],[0.110,0.093,0.013],[48.068,4.642,3.042],[5.025,4.935,0.492],[5.568,5.946,9.440],[4.658,3.116,2.543],[1.518,1.289,1.463],[0.982,0.865,0.918],[1.289,1.317,1.234],[4.156,3.990,4.480],[48.903,51.670,49.754],[0.162,0.150,0.140],[2.374,2.245,2.503],[3.489,2.974,3.144],[27.652,24.767,26.609],[21.671,20.719,19.494],[19.184,19.208,23.210],[1.686,1.406,1.352],[0.174,0.152,0.140],[0.057,0.064,0.061],[0.059,0.059,0.056],[0.264,0.295,0.344],[0.029,0.026,0.023],[0.023,0.020,0.020],[0.018,0.019,0.018]],"source":"clickhouse-cloud/results/azure.3.8.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":382.264,"data_size":9941673163,"result":[[0.003,0.030,0.002],[0.076,0.023,0.024],[0.360,0.287,0.303],[0.494,0.409,0.517],[2.403,2.828,1.777],[3.604,2.799,2.820],[0.027,0.026,0.025],[0.021,0.022,0.022],[2.307,2.178,2.043],[2.540,2.111,2.498],[0.572,0.595,0.540],[0.860,0.829,0.710],[2.581,2.774,2.466],[4.180,4.075,3.798],[3.045,3.132,3.090],[1.857,1.531,1.725],[11.376,8.572,11.614],[4.398,8.375,8.097],[20.418,20.504,19.592],[0.058,0.008,0.008],[4.235,1.810,2.015],[5.012,0.425,0.400],[5.701,2.663,2.700],[2.626,2.545,2.466],[1.223,1.316,1.281],[0.832,0.905,0.831],[1.209,1.188,1.257],[4.335,4.427,4.178],[28.768,29.188,28.215],[0.142,0.109,0.150],[2.651,2.436,2.310],[3.494,3.544,3.429],[18.006,16.317,16.364],[13.987,14.464,14.153],[14.449,13.885,14.398],[0.930,0.849,0.929],[0.114,0.113,0.109],[0.047,0.049,0.050],[0.043,0.042,0.044],[0.214,0.206,0.212],[0.029,0.025,0.026],[0.023,0.021,0.022],[0.020,0.020,0.016]],"source":"clickhouse-cloud/results/gcp.1.12.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":1,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":701.314,"data_size":9947797593,"result":[[0.011,0.022,0.009],[0.119,0.166,0.151],[0.594,0.637,0.625],[0.842,0.815,0.718],[4.012,4.402,4.670],[6.352,5.105,5.037],[0.084,0.109,0.051],[0.091,0.041,0.035],[4.728,4.179,4.387],[5.273,3.300,3.233],[0.784,0.734,0.729],[0.916,0.907,1.043],[3.114,3.322,3.392],[5.481,9.335,5.779],[4.204,3.945,3.644],[2.732,2.255,1.991],[12.769,13.938,14.197],[10.443,9.418,9.702],[22.858,23.103,22.844],[0.123,0.011,0.011],[5.588,2.305,2.012],[5.801,0.511,0.498],[6.306,2.977,3.017],[3.045,2.689,2.788],[1.450,1.384,1.392],[0.940,0.935,1.101],[1.416,1.406,1.376],[4.978,4.701,4.622],[32.571,33.401,37.023],[0.191,0.186,0.170],[3.294,3.483,3.207],[3.844,3.674,3.459],[33.341,35.387,39.265],[32.813,27.477,25.227],[23.670,24.133,24.281],[1.559,1.270,1.260],[0.189,0.168,0.207],[0.063,0.072,0.061],[0.069,0.057,0.063],[0.331,0.466,0.400],[0.036,0.031,0.031],[0.032,0.030,0.026],[0.026,0.022,0.024]],"source":"clickhouse-cloud/results/gcp.1.8.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":437.102,"data_size":9941464017,"result":[[0.002,0.003,0.003],[0.308,0.021,0.081],[0.332,0.135,0.124],[0.371,0.324,0.693],[2.351,1.165,1.151],[4.311,4.702,4.229],[0.075,0.179,0.032],[0.096,0.026,0.026],[2.616,1.940,2.610],[2.241,3.295,2.592],[0.685,0.599,0.613],[0.713,0.538,0.920],[2.529,2.934,2.240],[3.708,3.838,3.795],[2.883,4.332,4.121],[1.449,1.205,1.265],[10.115,6.933,9.735],[3.541,6.212,6.640],[19.788,17.242,15.661],[0.117,0.009,0.012],[18.336,4.710,1.536],[5.231,0.467,3.740],[5.988,19.338,2.100],[49.278,2.097,1.843],[0.986,0.979,1.037],[0.946,0.856,0.936],[1.605,1.354,1.008],[5.286,4.660,3.166],[36.093,23.152,22.519],[0.287,0.111,0.113],[1.988,1.931,4.343],[2.827,2.485,2.420],[30.829,19.603,24.007],[17.429,31.147,16.999],[18.041,25.318,17.034],[0.998,0.984,0.928],[0.126,0.115,0.342],[0.063,0.050,0.051],[0.184,0.045,0.044],[0.398,0.241,0.229],[0.346,0.034,0.029],[0.588,0.029,0.024],[0.019,0.212,0.018]],"source":"clickhouse-cloud/results/gcp.2.12.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":71.757,"data_size":9950934429,"result":[[0.002,0.002,0.002],[0.509,0.090,0.023],[0.035,0.034,0.032],[0.290,0.041,0.035],[0.284,0.287,0.221],[0.292,0.300,0.284],[0.265,0.011,0.013],[0.016,0.016,0.116],[0.304,0.299,0.540],[0.607,0.373,0.310],[0.157,0.162,0.317],[0.149,0.154,0.276],[0.656,0.475,0.336],[0.470,0.471,0.484],[0.567,0.319,0.295],[0.207,0.214,0.165],[0.876,0.855,1.072],[0.567,0.677,0.604],[1.722,2.191,1.656],[0.020,0.244,0.005],[0.382,0.192,0.197],[2.252,0.470,0.080],[1.901,0.282,0.520],[0.414,0.383,0.398],[0.142,0.465,0.160],[0.108,0.118,0.112],[0.147,0.149,0.137],[0.413,0.592,0.416],[3.637,2.051,2.113],[0.361,0.033,0.036],[0.633,0.305,0.254],[1.233,0.452,0.433],[2.052,1.905,1.787],[1.242,1.227,1.145],[1.360,1.367,1.274],[0.165,0.180,0.133],[0.046,0.043,0.204],[0.027,0.029,0.032],[0.037,0.036,0.034],[0.242,0.095,0.091],[0.314,0.019,0.020],[0.198,0.017,0.017],[0.012,0.013,0.014]],"source":"clickhouse-cloud/results/gcp.2.120.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":324.653,"data_size":9942238542,"result":[[0.003,0.003,0.002],[0.061,0.808,0.023],[0.943,0.118,0.111],[0.326,0.287,0.533],[1.631,1.613,1.680],[1.925,1.438,2.636],[0.047,0.232,0.026],[0.137,0.024,0.020],[2.388,2.213,1.808],[2.101,2.293,2.349],[0.494,0.474,0.357],[0.621,0.650,0.624],[1.634,1.735,2.215],[2.698,2.348,3.598],[2.719,2.559,2.309],[1.133,1.481,1.022],[6.771,4.314,4.264],[3.315,3.759,2.558],[13.795,8.403,12.646],[0.266,0.007,0.008],[13.030,3.262,1.536],[3.526,2.721,0.275],[13.408,1.534,1.593],[2.102,42.297,2.198],[1.171,0.707,1.159],[0.759,0.759,0.543],[1.135,0.765,0.732],[3.808,2.538,2.848],[26.327,23.495,22.788],[0.140,0.329,0.093],[1.910,1.900,2.950],[5.604,3.181,2.084],[14.253,13.219,13.976],[16.989,8.592,13.249],[9.306,7.021,10.924],[0.880,0.932,0.655],[0.280,0.140,0.108],[0.360,0.064,0.064],[0.048,0.046,0.049],[0.239,0.249,0.363],[0.300,0.030,0.031],[0.025,0.252,0.052],[0.237,0.018,0.020]],"source":"clickhouse-cloud/results/gcp.2.16.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 236GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":83.930,"data_size":9952437197,"result":[[0.003,0.003,0.002],[0.029,0.301,0.027],[0.035,0.383,0.041],[0.284,0.038,0.039],[0.234,0.235,0.298],[0.237,0.234,0.594],[0.183,0.018,0.018],[0.020,0.174,0.022],[0.447,0.766,0.462],[0.611,0.461,0.466],[0.150,0.352,0.172],[0.153,0.381,0.149],[0.292,0.654,0.282],[0.468,0.396,0.441],[0.320,0.562,0.669],[0.191,0.250,0.163],[0.825,0.862,0.598],[0.433,0.494,0.425],[1.693,1.277,1.193],[0.024,0.282,0.008],[0.307,0.176,0.183],[0.389,0.112,0.083],[2.091,0.442,0.270],[0.388,53.857,0.407],[0.148,0.130,0.123],[0.101,0.087,0.100],[0.123,0.123,0.125],[0.410,0.410,0.421],[2.173,1.726,1.635],[0.039,0.049,0.040],[0.282,0.488,0.291],[0.414,0.363,0.363],[2.028,1.700,1.540],[1.168,1.481,1.380],[1.229,1.221,1.111],[0.098,0.089,0.135],[0.063,0.202,0.062],[0.040,0.039,0.039],[0.037,0.211,0.038],[0.106,0.098,0.106],[0.020,0.021,0.315],[0.020,0.019,0.020],[0.018,0.014,0.017]],"source":"clickhouse-cloud/results/gcp.2.236.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":159.359,"data_size":9946277274,"result":[[0.002,0.003,0.002],[0.346,0.072,0.021],[0.371,0.139,0.166],[0.308,0.143,0.336],[1.216,1.189,1.035],[1.310,1.139,0.880],[0.019,0.187,0.018],[0.019,0.166,0.015],[0.948,0.951,0.978],[1.148,1.126,0.911],[0.343,0.422,0.273],[0.520,0.384,0.298],[0.972,0.885,0.865],[1.516,1.521,1.732],[1.322,1.320,1.060],[0.728,0.518,0.485],[2.449,2.755,2.227],[1.437,1.239,1.258],[5.002,5.529,5.527],[0.035,0.007,0.114],[6.760,0.546,0.559],[1.702,0.166,0.155],[1.859,0.878,0.903],[46.169,1.666,0.960],[0.462,0.406,0.376],[0.264,0.274,0.296],[0.443,0.380,0.424],[1.390,1.257,1.446],[12.607,8.415,8.814],[0.068,0.074,0.067],[1.077,0.849,0.782],[1.117,3.191,1.178],[4.264,4.113,4.151],[4.317,3.880,4.075],[4.283,4.287,4.347],[0.534,0.467,0.489],[0.070,0.067,0.234],[0.403,0.037,0.044],[0.044,0.042,0.039],[0.226,0.604,0.132],[0.021,0.021,0.195],[0.276,0.019,0.019],[0.210,0.019,0.021]],"source":"clickhouse-cloud/results/gcp.2.32.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":78.073,"data_size":9948389796,"result":[[0.003,0.003,0.002],[0.019,0.018,0.022],[0.392,0.045,0.038],[0.053,0.053,0.054],[0.661,0.343,0.312],[0.496,0.509,0.501],[0.166,0.016,0.011],[0.138,0.014,0.014],[0.516,0.483,0.459],[0.764,0.503,0.512],[0.169,0.331,0.163],[0.313,0.202,0.187],[0.619,0.364,0.377],[0.779,0.700,0.715],[0.639,0.607,0.560],[0.313,0.303,0.314],[1.140,1.541,0.923],[0.555,0.714,0.947],[2.633,2.385,2.311],[0.093,0.005,0.006],[0.684,0.304,0.295],[3.603,0.100,0.097],[0.857,3.330,0.391],[47.414,0.548,0.473],[0.215,0.194,0.195],[0.148,0.147,0.187],[0.217,0.208,0.208],[0.649,0.648,0.638],[4.240,6.231,4.148],[0.042,0.050,0.050],[0.452,0.676,0.434],[0.637,1.864,0.624],[2.299,2.426,2.117],[1.885,1.811,2.115],[2.065,1.855,1.875],[0.212,0.199,0.237],[0.172,0.074,0.070],[0.047,0.037,0.032],[0.191,0.038,0.031],[0.105,0.105,0.244],[0.244,0.022,0.023],[0.017,0.021,0.227],[0.014,0.014,0.013]],"source":"clickhouse-cloud/results/gcp.2.64.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":2,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":664.666,"data_size":9943981030,"result":[[0.004,0.003,0.003],[0.130,0.285,0.114],[0.416,0.661,0.241],[0.990,0.966,0.271],[1.815,1.811,1.768],[7.672,3.801,2.980],[0.180,0.038,0.112],[0.071,0.035,0.133],[7.176,2.964,6.697],[3.554,7.379,3.448],[1.804,1.467,0.919],[1.403,1.000,0.864],[2.878,2.748,5.065],[4.604,5.422,7.456],[4.107,3.330,6.985],[2.030,3.824,1.688],[23.130,8.948,11.512],[19.035,15.835,16.628],[32.465,25.550,27.967],[0.095,0.013,0.011],[28.021,5.134,2.186],[5.557,5.669,0.518],[6.789,28.352,3.029],[2.923,40.467,2.765],[1.391,1.452,1.322],[1.031,0.980,1.113],[1.811,1.770,1.443],[4.725,4.932,4.773],[52.665,34.395,34.262],[0.176,0.151,0.364],[2.991,4.413,3.246],[12.665,3.955,4.290],[29.312,29.449,27.635],[26.189,25.365,27.155],[24.691,24.391,23.425],[1.269,1.332,1.366],[0.176,0.298,0.177],[0.077,0.074,0.061],[0.072,0.073,0.072],[0.429,0.410,0.382],[0.226,0.052,0.032],[0.035,0.029,0.028],[0.022,0.022,0.023]],"source":"clickhouse-cloud/results/gcp.2.8.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 12GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":397.794,"data_size":9941328110,"result":[[0.002,0.002,0.002],[0.387,0.023,0.031],[0.198,0.191,0.206],[0.325,0.691,0.318],[1.467,1.148,2.212],[2.418,2.206,1.915],[0.461,0.145,0.029],[0.164,0.163,0.026],[2.158,2.230,1.800],[2.598,1.857,1.885],[0.578,0.548,0.545],[0.689,0.620,0.501],[2.014,2.011,2.946],[2.965,2.718,4.714],[2.664,2.192,1.808],[1.177,1.159,1.853],[4.912,6.129,9.038],[8.687,3.473,5.063],[18.126,15.049,23.671],[0.247,0.067,0.185],[5.010,15.784,17.299],[3.831,0.376,5.261],[19.197,16.035,1.972],[40.117,1.838,1.910],[1.470,1.229,0.922],[1.156,0.626,0.611],[1.838,1.265,0.985],[17.977,3.323,2.802],[34.875,21.399,21.044],[0.141,0.338,0.111],[2.103,2.791,3.424],[7.895,5.895,2.650],[16.281,16.897,16.410],[16.312,8.512,24.054],[13.933,14.587,13.360],[0.886,0.882,0.934],[0.340,0.107,0.267],[0.065,0.342,0.048],[0.186,0.054,0.121],[0.264,0.437,0.491],[0.270,0.216,0.025],[0.027,0.026,0.329],[0.248,0.021,0.016]],"source":"clickhouse-cloud/results/gcp.3.12.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 120GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":89.871,"data_size":9945899390,"result":[[0.003,0.003,0.003],[0.027,0.296,0.242],[0.040,0.254,0.884],[0.549,0.944,0.039],[0.396,0.274,0.323],[0.356,0.920,0.344],[0.179,0.015,0.111],[0.137,0.076,0.018],[0.520,0.288,0.282],[0.877,0.433,0.461],[0.186,0.321,0.168],[0.405,0.340,0.174],[0.548,0.392,0.397],[0.696,0.660,0.849],[0.402,0.508,0.743],[0.353,0.365,0.200],[1.408,1.185,0.974],[0.696,0.680,0.696],[2.954,1.972,2.045],[0.028,0.105,0.007],[2.027,0.234,1.190],[0.536,0.413,0.060],[2.012,1.261,0.555],[53.093,51.300,0.673],[0.171,0.164,0.162],[0.121,0.115,0.113],[0.164,0.158,0.154],[0.540,0.390,0.414],[3.517,2.274,2.338],[0.176,0.040,0.033],[0.620,0.311,0.383],[3.425,0.464,0.444],[2.618,2.268,2.671],[1.478,1.674,1.633],[1.527,1.580,1.212],[0.221,0.232,0.170],[0.331,0.076,0.076],[0.032,0.184,0.033],[0.039,0.267,0.049],[0.406,0.126,0.080],[0.354,0.020,0.026],[0.211,0.657,0.019],[0.022,0.016,0.014]],"source":"clickhouse-cloud/results/gcp.3.120.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 16GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":368.610,"data_size":9941935965,"result":[[0.002,0.003,0.002],[0.639,0.078,0.021],[0.490,0.762,0.112],[0.292,0.577,0.180],[1.265,0.887,0.852],[1.852,2.636,2.707],[0.069,0.218,0.025],[0.155,0.087,0.028],[1.843,1.464,1.329],[1.506,2.142,1.545],[0.508,0.462,0.326],[0.518,0.514,0.409],[1.469,1.776,2.139],[3.880,2.485,4.016],[2.095,1.842,3.093],[1.930,1.674,1.543],[6.731,4.118,6.661],[4.053,3.522,2.696],[13.507,10.993,18.840],[0.223,0.007,0.059],[12.670,11.610,4.327],[4.441,2.586,0.233],[12.479,5.014,1.427],[39.949,2.342,2.183],[0.676,1.165,0.750],[0.464,0.467,0.460],[1.244,0.706,0.687],[3.766,3.861,2.745],[26.975,25.423,25.616],[0.233,0.088,0.152],[2.244,2.007,2.110],[4.468,3.117,5.803],[19.700,21.422,20.487],[10.160,15.139,17.040],[17.548,10.500,7.381],[0.773,0.643,1.100],[0.358,0.129,0.093],[0.059,0.415,0.254],[0.057,0.066,0.201],[0.257,0.220,0.243],[0.361,0.146,0.029],[0.030,0.029,0.225],[0.421,0.110,0.017]],"source":"clickhouse-cloud/results/gcp.3.16.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 236GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":74.701,"data_size":9951568554,"result":[[0.002,0.002,0.002],[0.282,0.234,0.077],[0.295,0.168,0.033],[0.336,0.038,0.101],[0.356,0.190,0.372],[0.587,0.289,0.387],[0.179,0.127,0.017],[0.165,0.020,0.022],[0.471,0.643,0.455],[0.470,0.548,0.583],[0.163,0.157,0.374],[0.315,0.168,0.359],[0.326,0.617,0.250],[0.440,0.363,0.428],[0.546,0.338,0.315],[0.281,0.154,0.186],[0.801,0.607,0.850],[0.584,0.450,0.543],[1.621,1.624,1.256],[0.031,0.106,0.007],[0.344,1.198,0.214],[1.053,0.083,0.086],[1.208,0.510,0.999],[48.813,0.399,45.162],[0.144,0.126,0.439],[0.096,0.098,0.102],[0.128,0.121,0.113],[0.509,0.435,0.442],[2.373,2.028,2.432],[0.119,0.042,0.040],[0.498,0.398,0.298],[0.441,0.923,0.377],[1.954,1.740,2.070],[1.538,1.234,1.388],[1.339,1.275,1.188],[0.115,0.149,0.132],[0.042,0.224,0.044],[0.289,0.288,0.032],[0.156,0.148,0.033],[0.092,0.085,0.221],[0.020,0.306,0.022],[0.222,0.019,0.017],[0.015,0.013,0.016]],"source":"clickhouse-cloud/results/gcp.3.236.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 32GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":180.870,"data_size":9946480991,"result":[[0.002,0.003,0.002],[0.448,0.029,0.050],[0.480,0.081,0.128],[0.477,0.254,0.282],[0.694,0.596,0.761],[1.362,1.042,0.722],[0.018,0.021,0.223],[0.176,0.021,0.023],[1.088,1.072,0.978],[1.659,1.005,0.982],[0.235,0.362,0.236],[0.428,0.300,0.282],[1.094,1.035,0.795],[1.736,1.740,1.716],[1.790,1.287,1.027],[0.858,0.862,0.526],[2.812,2.350,2.077],[1.309,1.492,1.426],[5.335,4.757,8.456],[0.034,0.156,0.121],[1.369,0.909,6.326],[1.336,7.011,0.220],[1.787,6.758,0.777],[0.932,39.239,41.863],[0.444,0.449,0.437],[0.274,0.259,0.371],[0.531,0.372,0.444],[1.181,1.743,1.689],[12.435,7.670,16.506],[0.247,0.315,0.091],[1.953,0.734,1.664],[1.082,1.037,3.707],[8.088,7.423,8.099],[3.916,4.041,8.402],[11.068,6.039,3.885],[0.520,0.471,0.484],[0.313,0.162,0.078],[0.039,0.038,0.343],[0.194,0.037,0.041],[0.119,0.110,0.102],[0.280,0.021,0.110],[0.020,0.259,0.021],[0.243,0.143,0.017]],"source":"clickhouse-cloud/results/gcp.3.32.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 64GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":97.011,"data_size":9946392501,"result":[[0.004,0.005,0.004],[0.333,0.200,0.018],[0.282,0.064,0.051],[0.325,0.089,0.058],[0.325,0.605,0.448],[0.970,0.613,0.960],[0.251,0.023,0.012],[0.138,0.015,0.018],[0.771,0.513,0.523],[0.783,0.779,0.633],[0.384,0.335,0.169],[0.383,0.225,0.242],[0.721,0.596,0.646],[0.940,0.959,0.985],[0.852,0.898,0.741],[0.406,0.420,0.332],[1.629,1.343,1.735],[1.044,0.871,1.157],[2.824,1.949,4.316],[0.117,0.006,0.031],[3.679,2.039,0.295],[0.984,0.871,0.109],[0.997,0.618,0.562],[46.709,45.033,0.957],[0.218,0.308,0.247],[0.163,0.165,0.145],[0.301,0.204,0.210],[0.657,0.756,0.926],[7.843,5.597,5.891],[0.461,0.045,0.059],[0.469,0.509,0.441],[1.715,0.608,1.500],[4.429,2.262,4.122],[1.959,2.302,1.950],[5.215,2.185,3.797],[0.270,0.306,0.264],[0.303,0.048,0.336],[0.360,0.040,0.034],[0.173,0.039,0.036],[0.094,0.393,0.127],[0.353,0.020,0.021],[0.246,0.214,0.019],[0.015,0.350,0.023]],"source":"clickhouse-cloud/results/gcp.3.64.json"}
+,{"system":"ClickHouse ☁️ (gcp)","date":"2025-10-16","machine":"ClickHouse ☁️: 8GiB","cluster_size":3,"proprietary":"yes","tuned":"no","comment":"","tags":["C++","column-oriented","ClickHouse derivative","managed","gcp"],"load_time":603.826,"data_size":9949084409,"result":[[0.002,0.002,0.002],[0.137,0.485,0.021],[0.408,0.995,0.308],[0.759,0.418,0.246],[1.652,3.017,2.691],[4.668,3.314,2.744],[0.245,0.094,0.038],[0.154,0.102,0.034],[2.356,3.222,2.322],[2.641,2.890,2.882],[0.711,0.584,0.726],[0.871,0.725,1.264],[2.601,3.961,2.971],[4.774,7.664,4.871],[4.774,3.253,5.312],[1.857,2.246,3.260],[9.256,12.202,11.268],[9.208,11.049,8.126],[22.766,31.048,24.788],[0.459,0.012,0.089],[25.428,26.480,4.819],[5.080,4.871,0.490],[26.400,2.943,3.131],[2.821,40.630,38.704],[1.486,1.511,1.345],[0.963,0.866,0.990],[1.326,1.397,1.484],[4.647,4.491,5.386],[49.899,31.148,46.293],[0.350,0.155,0.155],[4.175,3.146,3.267],[10.757,4.048,3.832],[26.637,32.442,27.504],[27.172,21.860,20.761],[20.523,23.490,26.847],[1.224,1.392,1.123],[0.469,0.175,0.200],[0.384,0.079,0.061],[0.069,0.062,0.061],[0.310,0.452,0.480],[0.039,0.041,0.033],[0.027,0.211,0.099],[0.028,0.025,0.022]],"source":"clickhouse-cloud/results/gcp.3.8.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.459,0.032,0.037],[1.2,0.07,0.072],[1.597,0.131,0.134],[1.622,0.117,0.124],[0.629,0.647,0.647],[1.288,0.885,0.894],[1.335,0.076,0.073],[0.068,0.071,0.071],[1.394,0.746,0.736],[0.991,0.889,0.901],[0.335,0.238,0.247],[0.373,0.268,0.267],[0.924,0.921,0.947],[1.353,1.356,1.359],[1.083,1.057,1.067],[0.749,0.755,0.743],[2.788,2.777,2.794],[1.785,1.773,1.805],[5.977,5.175,5.148],[0.115,0.11,0.109],[5.446,1.186,1.148],[2.044,1.388,1.343],[9.053,8.455,6.062],[19.899,19.439,19.522],[1.37,0.508,0.501],[0.327,0.325,0.32],[0.509,0.496,0.497],[2.972,1.116,1.125],[11.427,10.558,10.533],[1.046,0.1,0.099],[2.871,0.802,0.804],[3.259,1.363,1.251],[13.382,12.576,null],[5.423,11.796,4.35],[11.76,4.406,11.293],[0.709,0.528,0.559],[0.208,0.143,0.141],[0.202,0.093,0.093],[0.119,0.072,0.078],[0.238,0.221,0.202],[0.13,0.057,0.051],[0.075,0.051,0.049],[0.053,0.049,0.109]],"source":"clickhouse-datalake-partitioned/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.952,0.04,0.045],[2.139,0.057,0.065],[1.991,0.103,0.118],[2.16,0.114,0.116],[0.426,0.43,0.436],[1.103,0.539,0.533],[0.856,0.063,0.082],[0.056,0.06,0.06],[0.879,0.552,0.541],[0.68,0.661,0.653],[0.29,0.221,0.221],[0.313,0.243,0.241],[0.671,0.681,0.69],[0.989,0.98,0.993],[0.758,0.748,0.748],[0.522,0.517,0.525],[1.859,1.853,1.853],[1.153,1.29,1.152],[4.412,3.798,3.827],[0.105,0.099,0.104],[2.846,1.13,1.145],[1.417,1.365,1.362],[3.548,2.477,2.467],[10.856,11.016,10.847],[0.548,0.386,0.376],[0.28,0.286,0.278],[0.387,0.377,0.4],[1.542,1.112,1.121],[5.832,5.492,5.54],[0.25,0.084,0.083],[1.021,0.647,0.66],[1.491,1.114,1.111],[4.546,4.535,4.622],[3.374,3.084,3.123],[3.109,3.076,3.116],[0.365,0.366,0.369],[0.164,0.153,0.135],[0.097,0.098,0.1],[0.118,0.079,0.074],[0.234,0.211,0.207],[0.113,0.066,0.058],[0.083,0.062,0.054],[0.056,0.058,0.071]],"source":"clickhouse-datalake-partitioned/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[1.283,0.056,0.066],[3.515,0.142,0.141],[5.318,0.363,0.363],[4.716,0.271,0.265],[1.825,1.832,1.846],[3.822,3.05,3.054],[4.062,0.151,0.164],[0.415,0.145,0.148],[5.16,2.369,2.375],[4.176,2.96,2.938],[1.11,0.705,0.693],[1.269,0.822,0.83],[3.003,2.936,2.946],[6.984,6.843,6.809],[3.788,3.522,3.544],[2.012,2.005,1.987],[12.042,11.629,11.873],[9.039,9.067,9.137],[29.872,39.124,35.283],[0.268,0.242,0.242],[18.923,19.569,18.306],[20.011,19.704,19.524],[38.477,38.561,38.854],[87.488,86.114,84.587],[8.51,1.635,1.629],[1.018,1.025,1.021],[1.642,1.635,1.639],[21.857,21.598,21.014],[45.728,45.496,45.064],[4.259,0.247,0.248],[15.821,7.366,2.576],[18.014,15.918,15.412],[null,null,null],[null,73.869,null],[354.51,null,null],[16.551,1.384,1.408],[0.802,0.298,0.248],[0.324,0.154,0.149],[0.225,0.121,0.117],[0.9,0.371,0.379],[0.329,0.115,0.092],[0.095,0.092,0.086],[0.133,0.083,0.087]],"source":"clickhouse-datalake-partitioned/results/c6a.large.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.179,0.076,0.059],[0.324,0.096,0.101],[0.374,0.139,0.137],[0.349,0.139,0.125],[0.305,0.293,0.298],[0.497,0.28,0.292],[0.334,0.101,0.1],[0.11,0.116,0.096],[0.6,0.433,0.409],[0.526,0.465,0.441],[0.321,0.226,0.22],[0.267,0.219,0.202],[0.306,0.318,0.298],[0.332,0.328,0.358],[0.354,0.354,0.299],[0.234,0.24,0.231],[0.499,0.534,0.496],[0.419,0.418,0.421],[1.165,0.888,0.9],[0.128,0.133,0.139],[3.28,0.437,0.411],[0.464,0.451,0.475],[2.415,0.673,0.682],[6.09,0.847,0.824],[0.192,0.184,0.204],[0.183,0.166,0.179],[0.199,0.199,0.191],[0.393,0.397,0.397],[1.489,1.51,1.407],[0.129,0.137,0.126],[0.258,0.273,0.273],[0.401,0.372,0.38],[1.312,1.351,1.339],[0.875,0.882,0.896],[0.867,0.92,0.87],[0.198,0.194,0.2],[0.166,0.183,0.172],[0.142,0.149,0.146],[0.118,0.102,0.116],[0.222,0.208,0.218],[0.105,0.102,0.106],[0.093,0.105,0.088],[0.086,0.093,0.086]],"source":"clickhouse-datalake-partitioned/results/c6a.metal.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.708,0.042,0.044],[1.946,0.086,0.085],[3.004,0.204,0.206],[2.488,0.163,0.16],[0.963,0.951,0.97],[1.755,1.576,1.564],[2.368,0.091,0.095],[0.088,0.089,0.092],[2.632,1.279,1.272],[1.745,1.575,1.565],[0.581,0.377,0.378],[0.628,0.444,0.468],[1.567,1.563,1.576],[2.389,2.378,2.395],[1.812,1.765,1.757],[1.054,1.06,1.061],[6.662,6.693,6.652],[4.958,4.882,2.838],[15.363,13.204,13.17],[0.148,0.146,0.15],[10.612,10.148,9.731],[10.811,10.867,10.627],[20.216,20.189,20.272],[45.724,45.59,44.272],[4.763,0.878,0.863],[0.556,0.554,0.544],[0.87,0.883,0.863],[11.745,11.015,11.035],[23.144,22.12,20.743],[2.083,0.143,0.141],[7.908,1.361,1.34],[7.609,2.392,2.184],[30.053,21.272,32.067],[21.834,20.916,19.542],[18.983,20.557,25.338],[2.417,0.869,0.858],[0.42,0.163,0.156],[0.205,0.102,0.101],[0.107,0.086,0.077],[0.365,0.238,0.239],[0.126,0.063,0.066],[0.092,0.059,0.061],[0.062,0.058,0.059]],"source":"clickhouse-datalake-partitioned/results/c6a.xlarge.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.164,0.082,0.099],[0.31,0.113,0.119],[0.412,0.15,0.126],[0.343,0.134,0.141],[0.493,0.468,0.477],[0.626,0.474,0.517],[0.321,0.12,0.117],[0.111,0.109,0.113],[0.583,0.409,0.434],[0.504,0.451,0.454],[0.281,0.24,0.249],[0.276,0.221,0.227],[0.312,0.297,0.287],[0.37,0.366,0.325],[0.311,0.28,0.279],[0.253,0.244,0.235],[0.439,0.411,0.41],[0.374,0.411,0.379],[0.964,0.691,0.71],[0.136,0.124,0.128],[1.864,0.493,0.463],[0.587,0.525,0.538],[1.326,0.636,0.563],[3.804,0.728,0.676],[0.216,0.201,0.2],[0.207,0.191,0.222],[0.205,0.205,0.184],[0.425,0.362,0.432],[1.159,1.368,1.209],[0.142,0.143,0.144],[0.266,0.278,0.261],[0.367,0.361,0.372],[0.856,0.902,0.906],[0.733,0.757,0.689],[0.832,0.7,0.681],[0.212,0.211,0.223],[0.216,0.199,0.215],[0.162,0.154,0.152],[0.125,0.129,0.127],[0.202,0.257,0.226],[0.142,0.115,0.111],[0.111,0.118,0.122],[0.108,0.119,0.109]],"source":"clickhouse-datalake-partitioned/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.227,0.038,0.042],[0.572,0.051,0.049],[0.852,0.082,0.085],[0.797,0.068,0.073],[0.218,0.223,0.216],[0.464,0.354,0.352],[0.669,0.051,0.052],[0.053,0.056,0.064],[0.764,0.293,0.311],[0.443,0.352,0.366],[0.248,0.154,0.16],[0.237,0.178,0.171],[0.349,0.362,0.336],[0.485,0.473,0.51],[0.435,0.41,0.403],[0.253,0.25,0.247],[0.906,0.896,0.813],[0.685,0.565,0.662],[2.4,1.642,1.634],[0.068,0.071,0.071],[3.517,0.542,0.496],[0.721,0.627,0.598],[3.5,0.995,1.003],[11.685,10.979,10.414],[0.511,0.228,0.219],[0.158,0.157,0.155],[0.221,0.245,0.226],[1.336,0.48,0.447],[3.541,3.064,2.99],[0.219,0.077,0.081],[0.912,0.324,0.343],[1.182,0.447,0.457],[1.762,1.744,1.766],[1.689,1.314,1.31],[1.301,1.318,1.289],[0.201,0.221,0.216],[0.144,0.103,0.108],[0.175,0.08,0.078],[0.142,0.065,0.062],[0.191,0.163,0.16],[0.157,0.049,0.046],[0.063,0.044,0.049],[0.045,0.044,0.051]],"source":"clickhouse-datalake-partitioned/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse (data lake, partitioned)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.168,0.094,0.09],[0.32,0.116,0.1],[0.432,0.119,0.127],[0.384,0.118,0.107],[0.333,0.357,0.371],[0.487,0.409,0.42],[0.338,0.113,0.104],[0.115,0.106,0.104],[0.495,0.346,0.331],[0.411,0.374,0.376],[0.296,0.192,0.199],[0.244,0.181,0.19],[0.226,0.234,0.222],[0.298,0.262,0.271],[0.286,0.247,0.247],[0.224,0.195,0.193],[0.372,0.364,0.347],[0.338,0.368,0.343],[1.04,0.66,0.652],[0.112,0.109,0.112],[1.68,0.395,0.352],[0.471,0.454,0.427],[1.329,0.603,0.605],[3.788,1.13,0.705],[0.175,0.187,0.184],[0.162,0.16,0.15],[0.181,0.176,0.181],[0.38,0.37,0.396],[1.318,1.201,1.259],[0.158,0.164,0.157],[0.239,0.242,0.235],[0.313,0.335,0.309],[0.85,0.915,0.849],[0.71,0.721,0.597],[0.697,0.641,0.595],[0.169,0.171,0.177],[0.175,0.172,0.174],[0.125,0.158,0.139],[0.125,0.125,0.135],[0.214,0.211,0.191],[0.109,0.13,0.116],[0.11,0.1,0.107],[0.117,0.111,0.096]],"source":"clickhouse-datalake-partitioned/results/c8g.metal-48xl.json"}
,{"system":"ClickHouse (data lake, partitioned)","date":"2025-08-31","machine":"t3a.small","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[1.316,0.083,0.083],[3.584,0.239,0.24],[6.015,4.035,0.654],[5.573,0.505,0.511],[3.648,3.525,3.648],[7.585,5.374,5.24],[4.163,0.261,0.261],[3.059,0.198,0.253],[7.297,4.874,4.547],[null,null,null],[2.965,1.578,1.508],[2.494,1.693,1.725],[32.159,null,12.992],[null,null,null],[12.642,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[1.056,0.462,0.474],[22.754,21.619,21.03],[26.078,25.535,25.44],[50.244,51.207,49.194],[104.43,97.282,91.485],[12.488,10.091,7.57],[2.258,2.061,2.116],[3.789,3.195,3.179],[25.817,24.615,23.932],[81.074,80.079,79.417],[5.779,0.374,0.327],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[19.283,2.713,2.614],[1.357,0.421,0.42],[0.61,0.236,0.276],[0.371,0.189,0.193],[1.403,0.812,0.678],[0.461,0.153,0.153],[0.153,0.145,0.121],[0.142,0.137,0.143]],"source":"clickhouse-datalake-partitioned/results/t3a.small.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.122,0.057,0.059],[12.65,0.104,0.1],[15.076,0.2,0.223],[18.671,0.154,0.168],[2.039,2.047,2.054],[4.675,3.047,3.031],[5.509,0.097,0.099],[0.111,0.091,0.091],[5.63,2.67,2.671],[3.144,3.141,3.141],[1.517,0.309,0.306],[1.535,0.37,0.368],[4.613,4.537,4.513],[4.003,4.067,4.022],[3.005,2.914,2.93],[2.193,2.2,2.234],[13.776,13.652,13.889],[10.835,11.21,11.136],[31.54,29.332,29.318],[0.167,0.145,0.146],[28.136,1.745,1.79],[6.856,2.241,2.261],[48.697,29.142,4.461],[117.911,110.634,110.149],[6.76,0.648,0.642],[0.547,0.548,0.526],[0.652,0.634,0.634],[18.331,2.218,2.247],[48.669,46.947,48.542],[4.467,0.127,0.126],[13.433,1.485,1.526],[12.566,2.817,2.932],[49.804,51.381,49.371],[29.657,27.633,26.789],[26.566,26.442,25.947],[1.571,1.521,1.506],[0.448,0.222,0.229],[0.318,0.127,0.124],[0.16,0.111,0.107],[0.533,0.406,0.413],[0.273,0.092,0.091],[0.115,0.08,0.086],[0.068,0.078,0.077]],"source":"clickhouse-datalake/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.234,0.059,0.06],[15.097,0.104,0.1],[15.078,0.23,0.233],[18.605,0.182,0.187],[2.043,2.019,2.055],[4.67,2.991,3.018],[5.547,0.077,0.078],[0.104,0.108,0.109],[5.732,2.68,2.616],[3.184,3.078,3.128],[1.433,0.285,0.278],[1.476,0.351,0.348],[2.837,2.853,2.815],[3.972,4.036,4.023],[3.006,2.906,2.957],[2.205,2.187,2.226],[9.35,9.413,9.405],[6.744,6.851,6.758],[18.737,17.938,18.024],[0.16,0.182,0.16],[28.136,1.581,1.618],[1.885,1.706,1.645],[33.233,3.047,3.043],[113.231,76.424,9.467],[0.451,0.449,0.453],[0.464,0.504,0.457],[0.454,0.441,0.45],[1.662,1.721,1.753],[44.692,46.702,44.444],[0.104,0.104,0.105],[1.347,1.364,1.364],[2.615,2.587,2.607],[24.591,24.692,24.72],[14.033,14.272,14.04],[14.03,14.039,14.034],[1.494,1.496,1.516],[0.219,0.229,0.223],[0.124,0.137,0.129],[0.108,0.107,0.107],[0.38,0.4,0.406],[0.091,0.086,0.084],[0.08,0.08,0.081],[0.077,0.08,0.073]],"source":"clickhouse-datalake/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.103,0.048,0.061],[6.214,0.148,0.14],[14.948,0.387,0.379],[18.275,0.285,0.277],[2.237,2.189,2.147],[4.076,null,null],[7.385,0.152,0.151],[0.149,0.146,0.156],[5.943,2.99,2.966],[3.57,3.545,3.595],[2.071,0.848,0.839],[2.113,0.987,0.987],[null,null,null],[8.619,8.342,8.068],[4.454,3.818,3.804],[2.485,2.412,2.498],[null,null,null],[null,null,null],[null,null,null],[0.244,0.257,0.237],[28.524,22.432,21.198],[34.445,33.284,34.553],[73.82,73.97,73.732],[154.618,150.562,150.072],[13.827,2.626,2.128],[1.258,1.273,1.272],[2.096,2.06,2.098],[40.419,32.585,31.118],[null,null,null],[5.899,0.239,0.241],[21.651,8.533,3.513],[22.2,17.974,15.183],[null,null,null],[null,null,null],[null,null,null],[9.852,1.62,1.659],[1.276,0.266,0.272],[0.381,0.189,0.19],[0.31,0.123,0.117],[1.504,0.469,0.467],[0.598,0.079,0.093],[0.151,0.102,0.092],[0.086,0.08,0.085]],"source":"clickhouse-datalake/results/c6a.large.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.118,0.061,0.058],[5.27,0.11,0.117],[7.13,0.307,0.318],[6.27,0.25,0.255],[1.955,1.983,1.953],[4.208,2.734,2.655],[5.452,0.121,0.113],[0.126,0.131,0.134],[5.783,2.552,2.565],[2.985,2.948,3.02],[1.462,0.288,0.276],[1.535,0.357,0.341],[2.564,2.46,2.505],[3.667,4.57,3.799],[3.175,2.548,2.553],[2.367,2.513,2.344],[8.538,8.47,8.561],[6.189,6.077,6.14],[18.991,15.826,15.885],[0.234,0.249,0.232],[28.273,1.756,1.812],[1.733,1.399,1.491],[33.352,2.551,2.631],[94.606,6.449,6.377],[0.502,0.474,0.482],[0.52,0.538,0.533],[0.483,0.485,0.476],[1.485,1.483,1.504],[45.973,43.63,43.675],[0.162,0.14,0.157],[1.44,1.329,1.377],[2.538,2.624,2.477],[22.612,20.863,20.886],[13.181,11.897,13.419],[12.118,12.026,12.306],[1.606,1.509,1.355],[0.233,0.242,0.223],[0.149,0.139,0.143],[0.128,0.124,0.138],[0.404,0.415,0.41],[0.106,0.103,0.102],[0.082,0.084,0.116],[0.074,0.092,0.097]],"source":"clickhouse-datalake/results/c6a.metal.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.109,0.058,0.055],[8.552,0.101,0.1],[15.077,0.247,0.246],[18.543,0.189,0.183],[2.019,2.05,2.019],[4.713,null,null],[7.178,0.11,0.106],[0.115,0.111,0.113],[5.867,2.655,2.703],[3.149,3.157,3.053],[1.655,0.46,0.445],[1.648,0.507,0.521],[null,null,null],[4.101,4.136,4.115],[3.128,3.01,3.018],[2.131,2.153,2.182],[15.393,15.39,15.443],[9.877,9.823,9.786],[30.792,29.455,30.194],[0.172,0.173,0.158],[28.203,26.965,26.44],[33.531,33.466,33.673],[66.589,66.835,67.463],[149.967,151.105,150.132],[13.091,1.016,1.015],[0.66,0.665,0.668],[1.019,1.006,1.017],[32.882,31.263,31.329],[60.005,58.002,57.461],[5.814,0.159,0.158],[21.533,1.906,1.888],[15.989,2.924,2.962],[37.408,37.766,38.485],[null,null,null],[null,31.789,null],[6.056,1.517,1.486],[0.605,0.233,0.238],[0.351,0.118,0.132],[0.178,0.105,0.106],[0.802,0.408,0.409],[0.308,0.091,0.082],[0.142,0.083,0.085],[0.081,0.075,0.071]],"source":"clickhouse-datalake/results/c6a.xlarge.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.229,0.055,0.055],[19.796,0.103,0.107],[23.904,0.298,0.292],[22.104,0.222,0.221],[1.909,1.919,1.902],[7.624,2.921,2.953],[14.149,0.115,0.098],[0.112,0.101,0.119],[12.312,2.456,2.495],[3.653,2.95,2.926],[3.193,0.29,0.29],[1.988,0.356,0.361],[2.402,2.4,2.375],[3.542,3.492,3.558],[3.818,2.392,2.316],[2.215,2.239,2.2],[7.946,7.925,9.398],[5.872,5.98,5.912],[34.114,16.181,15.936],[0.206,0.199,0.218],[70.644,1.691,1.63],[2.058,1.301,1.316],[71.261,2.223,2.201],[242.977,5.917,5.95],[0.469,0.466,0.467],[0.481,0.465,0.467],[0.472,0.492,0.479],[1.335,1.42,1.289],[36.207,35.356,36.456],[0.152,0.142,0.149],[1.457,1.36,1.366],[2.777,2.671,2.665],[18.51,18.541,18.465],[12.151,12.01,15.861],[12.248,12.329,12.325],[1.427,1.536,1.531],[0.217,0.216,0.221],[0.145,0.155,0.142],[0.121,0.126,0.115],[0.453,0.444,0.392],[0.092,0.105,0.103],[0.11,0.096,0.094],[0.091,0.085,0.092]],"source":"clickhouse-datalake/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-28","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.26,0.051,0.054],[22.424,0.143,0.104],[24.518,0.167,0.167],[24.628,0.142,0.143],[1.528,1.529,1.561],[6.779,2.682,2.667],[8.595,0.09,0.091],[0.088,0.095,0.092],[5.811,2.034,2.045],[2.529,2.486,2.506],[1.503,0.187,0.204],[1.417,0.244,0.265],[2.209,2.256,2.225],[2.975,2.991,2.999],[2.392,2.206,2.22],[1.622,1.627,1.623],[7.921,7.886,7.884],[5.755,5.695,5.745],[24.907,15.223,15.171],[0.13,0.126,0.129],[36.76,1.724,1.711],[1.424,1.166,1.161],[38.178,2.062,2.055],[133.047,66.375,3.421],[0.3,0.304,0.296],[0.369,0.364,0.437],[0.287,0.295,0.3],[0.994,0.998,0.974],[38.254,38.285,38.282],[0.099,0.1,0.121],[0.953,0.952,0.965],[1.855,1.847,1.83],[17.173,17.367,17.351],[11.47,11.234,11.408],[11.403,11.448,11.792],[1.078,1.091,1.076],[0.177,0.182,0.18],[0.099,0.105,0.1],[0.093,0.091,0.092],[0.315,0.318,0.321],[0.096,0.073,0.075],[0.072,0.069,0.065],[0.066,0.063,0.05]],"source":"clickhouse-datalake/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse (data lake, single)","date":"2025-08-28","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.111,0.056,0.057],[16.916,0.113,0.114],[24.388,0.232,0.232],[24.602,0.187,0.186],[1.531,1.531,1.535],[6.65,2.632,2.632],[8.444,0.101,0.104],[0.109,0.104,0.117],[5.732,2.014,2],[3.336,2.559,2.521],[1.485,0.256,0.242],[1.425,0.338,0.317],[2.224,2.235,2.234],[3.038,3.048,3.049],[3.185,2.302,2.319],[1.66,1.669,1.668],[7.82,7.789,7.886],[5.79,5.757,5.752],[22.7,14.776,14.504],[0.184,0.173,0.158],[38.366,2.101,2.013],[1.279,1.064,1.044],[35.558,1.788,1.819],[119.694,4.623,4.571],[0.361,0.375,0.37],[0.459,0.459,0.47],[0.368,0.367,0.369],[1.042,1.08,1.067],[39.286,39.633,40.464],[0.168,0.167,0.165],[1.282,1.243,1.229],[2.337,2.226,2.225],[16.148,16.293,16.205],[10.741,10.629,10.623],[10.592,10.439,10.724],[1.107,1.1,1.1],[0.184,0.2,0.197],[0.124,0.126,0.123],[0.109,0.11,0.112],[0.328,0.338,0.332],[0.086,0.089,0.088],[0.087,0.08,0.086],[0.079,0.081,0.081]],"source":"clickhouse-datalake/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.116,0.06,0.059],[13.655,0.101,0.098],[14.501,0.21,0.234],[15.632,0.169,0.173],[2.026,2.037,2.05],[3.557,2.979,3.019],[5.578,0.095,0.097],[0.11,0.092,0.1],[5.734,2.65,2.674],[3.145,3.096,3.121],[1.532,0.292,0.282],[1.477,0.355,0.352],[4.531,4.45,4.484],[3.975,3.968,3.945],[3.004,2.914,2.952],[2.226,2.207,2.218],[13.578,13.548,13.715],[10.842,11.376,11.458],[32.581,29.357,30.223],[0.14,0.152,0.154],[28.417,1.4,1.366],[9.928,1.97,1.966],[51.422,39.256,13.007],[119.383,118.953,119.965],[3.74,0.557,0.557],[0.485,0.484,0.491],[0.55,0.56,0.554],[8.855,1.431,1.414],[46.716,46.111,45.702],[4.95,0.122,0.119],[14.533,1.543,1.56],[15.125,2.89,2.852],[42.003,46.43,41.883],[24.435,23.901,24.168],[24.485,24.018,24.064],[1.494,1.489,1.498],[0.437,0.233,0.23],[0.121,0.13,0.126],[0.191,0.109,0.109],[0.7,0.381,0.374],[0.366,0.085,0.091],[0.129,0.084,0.061],[0.08,0.078,0.073]],"source":"clickhouse-datalake/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.139,0.064,0.062],[16.549,0.108,0.108],[14.457,0.256,0.251],[15.561,0.211,0.197],[2.317,2.345,2.343],[3.535,3.258,3.232],[5.511,0.1,0.101],[0.103,0.114,0.114],[5.773,2.984,3.007],[3.485,3.468,3.462],[1.519,0.282,0.31],[1.481,0.369,0.371],[3.173,3.172,3.158],[4.618,4.604,4.692],[3.517,3.33,3.359],[2.434,2.484,2.486],[10.899,10.813,10.934],[7.764,7.828,7.825],[22.282,21.161,21.493],[0.191,0.192,0.198],[28.571,1.797,1.778],[2.135,1.929,1.945],[33.405,3.616,3.61],[124.771,124.962,124.452],[1.16,0.527,0.513],[0.54,0.552,0.536],[0.532,0.499,0.519],[8.535,1.635,1.7],[50.083,45.089,45.095],[0.128,0.117,0.12],[7.812,1.811,1.795],[10.087,3.337,3.307],[28.9,28.903,28.851],[16.012,15.717,15.898],[15.716,15.305,16.031],[1.659,1.672,1.66],[0.356,0.254,0.238],[0.134,0.135,0.128],[0.229,0.105,0.116],[0.54,0.431,0.439],[0.265,0.091,0.081],[0.138,0.075,0.087],[0.085,0.078,0.083]],"source":"clickhouse-datalake/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.105,0.073,0.057],[5.133,0.146,0.147],[7.142,0.369,0.367],[14.572,0.27,0.262],[2.224,2.248,2.147],[3.89,null,null],[6.617,0.147,0.156],[0.162,0.151,0.148],[6.084,3.008,2.923],[3.657,3.626,3.623],[1.798,0.642,0.645],[1.972,0.786,0.792],[null,null,null],[8.211,7.831,7.895],[4.087,3.6,3.613],[2.42,2.39,2.405],[null,null,null],[null,null,null],[285.344,null,null],[0.252,0.247,0.239],[28.433,28.398,28.572],[34.271,34.525,34.424],[71.824,71.936,71.97],[153.764,154.798,154.562],[9.522,1.688,1.706],[1.02,1.028,1.013],[1.684,1.687,1.673],[35.394,34.865,34.755],[null,null,null],[0.707,0.245,0.248],[20.186,2.416,2.457],[28.876,24.093,23.786],[null,null,null],[null,null,null],[null,null,null],[9.825,1.625,1.632],[1.06,0.26,0.258],[0.474,0.157,0.161],[0.308,0.124,0.124],[1.045,0.451,0.432],[0.494,0.098,0.102],[0.235,0.091,0.089],[0.123,0.084,0.083]],"source":"clickhouse-datalake/results/c6a.large.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.121,0.058,0.056],[5.259,0.137,0.139],[8.963,0.362,0.36],[15.343,0.26,0.265],[2.051,2.037,2.064],[4.328,2.844,2.879],[5.572,0.146,0.136],[0.137,0.153,0.133],[5.915,2.721,2.678],[3.177,3.146,3.173],[1.599,0.316,0.279],[1.508,0.381,0.379],[2.677,2.66,2.692],[3.973,4.004,3.963],[3.277,2.891,2.883],[2.49,2.733,2.402],[9.664,9.591,9.656],[7.024,7.039,7.167],[21.803,19.413,19.16],[0.239,0.248,0.225],[29.219,1.594,1.56],[1.723,1.437,1.459],[33.829,2.505,2.499],[94.425,6.617,6.722],[0.459,0.493,0.47],[0.54,0.549,0.519],[0.5,0.49,0.507],[1.718,1.722,1.667],[44.083,44.163,43.963],[0.163,0.181,0.17],[1.57,1.545,1.506],[2.882,2.829,2.862],[29.425,29.348,29.14],[14.424,14.407,14.561],[14.725,14.694,14.416],[1.529,1.591,1.762],[0.228,0.219,0.214],[0.135,0.128,0.125],[0.114,0.111,0.118],[0.398,0.403,0.397],[0.077,0.086,0.095],[0.09,0.086,0.079],[0.065,0.073,0.081]],"source":"clickhouse-datalake/results/c6a.metal.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.109,0.061,0.055],[5.826,0.11,0.104],[13.182,0.239,0.241],[15.283,0.185,0.183],[2.118,2.11,2.111],[3.426,null,null],[6.74,0.102,0.111],[0.111,0.118,0.112],[5.823,2.73,2.811],[3.29,3.306,3.319],[1.597,0.376,0.376],[1.629,0.46,0.445],[null,null,null],[4.277,4.239,4.254],[3.247,3.211,3.238],[2.249,2.248,2.253],[16.639,16.53,16.521],[10.304,10.282,10.288],[32.234,30.975,31.024],[0.175,0.172,0.167],[28.393,28.249,28.248],[34.334,34.39,34.41],[67.949,67.45,67.701],[150.055,150.246,150.95],[15.705,0.919,0.92],[0.608,0.589,0.582],[0.914,0.909,0.904],[33.003,32.517,32.557],[59.867,59.534,60.799],[6.365,0.162,0.157],[23.892,1.702,1.713],[14.471,5.773,8.495],[43.759,43.38,42.055],[null,null,null],[null,null,null],[12.243,1.527,1.521],[0.899,0.234,0.231],[0.355,0.134,0.133],[0.308,0.112,0.108],[0.935,0.418,0.388],[0.523,0.087,0.093],[0.138,0.087,0.086],[0.084,0.078,0.072]],"source":"clickhouse-datalake/results/c6a.xlarge.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.127,0.062,0.055],[5.422,0.114,0.12],[7.162,0.335,0.311],[6.472,0.239,0.235],[2.037,2.015,2.034],[4.47,3.074,3.022],[5.646,0.11,0.109],[0.131,0.117,0.136],[6.257,2.658,2.67],[3.096,3.147,3.16],[1.5,0.34,0.315],[1.52,0.355,0.343],[2.576,2.457,2.6],[3.91,3.886,3.847],[3.546,2.74,2.704],[2.316,2.342,2.307],[9.432,9.267,9.331],[6.849,7.058,6.952],[24.742,19.258,19.255],[0.222,0.202,0.222],[28.652,1.457,1.449],[1.591,1.333,1.351],[33.571,2.425,2.44],[94.077,6.382,6.446],[0.505,0.497,0.511],[0.486,0.462,0.486],[0.503,0.498,0.493],[1.64,1.657,1.682],[37.317,37.091,37.361],[0.17,0.165,0.163],[1.754,1.843,1.826],[3.336,2.904,3.062],[25.455,25.254,25.341],[14.715,14.537,14.614],[14.582,14.346,14.295],[1.522,1.58,1.568],[0.212,0.22,0.214],[0.135,0.134,0.131],[0.12,0.122,0.118],[0.36,0.427,0.455],[0.103,0.095,0.074],[0.087,0.085,0.09],[0.074,0.076,0.079]],"source":"clickhouse-datalake/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.12,0.055,0.054],[5.041,0.102,0.108],[7.257,0.17,0.16],[13.206,0.141,0.135],[1.597,1.589,1.592],[5.123,2.763,2.777],[5.599,0.094,0.095],[0.099,0.088,0.084],[5.806,2.164,2.167],[2.677,2.708,2.673],[1.389,0.202,0.201],[1.38,0.269,0.271],[2.239,2.276,2.283],[3.241,3.22,3.238],[2.49,2.353,2.42],[1.663,1.675,1.648],[8.877,8.917,8.886],[6.425,6.475,6.466],[20.41,17.5,17.624],[0.12,0.135,0.111],[44.243,1.691,1.673],[1.49,1.118,1.131],[43.486,2.001,2.027],[120.322,126.286,122.124],[1.041,0.295,0.299],[0.368,0.374,0.388],[0.305,0.297,0.306],[5.429,0.911,0.891],[41.508,39.152,39.166],[0.106,0.111,0.098],[8.221,1.17,1.168],[9.573,2.249,2.259],[20.786,20.716,20.553],[12.237,12.029,12.054],[12.138,12.027,12.052],[1.116,1.132,1.119],[0.231,0.19,0.185],[0.09,0.11,0.103],[0.143,0.094,0.094],[0.403,0.315,0.318],[0.184,0.074,0.075],[0.093,0.072,0.067],[0.067,0.07,0.068]],"source":"clickhouse-datalake/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse (data lake, single)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.115,0.049,0.054],[5.054,0.126,0.141],[7.262,0.242,0.26],[6.261,0.187,0.189],[1.572,1.569,1.562],[4.257,2.611,2.599],[5.471,0.112,0.123],[0.119,0.128,0.127],[5.68,2.081,2.017],[2.54,2.554,2.543],[1.435,0.286,0.277],[1.456,0.348,0.357],[2.095,2.1,2.096],[2.941,2.906,2.925],[3.146,2.272,2.252],[1.661,1.665,1.677],[7.922,7.949,7.989],[5.882,5.875,5.877],[22.653,14.945,14.743],[0.166,0.185,0.176],[49.476,2.017,2.008],[1.334,1.092,1.044],[39.82,1.805,1.878],[92.779,4.75,4.625],[0.368,0.365,0.362],[0.445,0.439,0.443],[0.359,0.354,0.35],[1.238,1.238,1.223],[39.871,39.84,39.864],[0.173,0.185,0.178],[1.302,1.28,1.254],[2.343,2.269,2.216],[16.75,16.879,16.863],[10.51,10.301,10.409],[10.698,10.308,10.186],[1.101,1.093,1.109],[0.175,0.169,0.182],[0.112,0.101,0.105],[0.119,0.11,0.113],[0.312,0.318,0.31],[0.08,0.081,0.078],[0.074,0.071,0.064],[0.071,0.067,0.07]],"source":"clickhouse-datalake/results/c8g.metal-48xl.json"}
,{"system":"ClickHouse (data lake, single)","date":"2025-08-31","machine":"t3a.small","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.152,0.106,0.089],[5.263,0.266,0.254],[7.75,2.941,0.836],[6.719,0.632,0.63],[4.499,4.098,4.112],[7.818,null,null],[7.109,0.249,0.277],[5.235,0.283,0.262],[7.948,9.051,11.626],[18.685,null,null],[2.809,1.572,1.461],[2.878,1.729,1.661],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[1.494,0.543,0.645],[29.574,27.189,25.378],[44.727,44.012,44.623],[96.541,90.857,90.061],[195.719,161.405,160.167],[16.095,9.909,4.906],[2.165,2.202,2.191],[3.653,3.709,3.739],[46.951,43.039,44.189],[null,null,null],[12.108,0.57,0.578],[36.685,19.133,17.675],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[20.502,6.375,6.12],[1.55,0.483,0.491],[0.538,0.297,0.317],[0.411,0.203,0.21],[1.321,0.843,0.832],[0.614,0.171,0.183],[0.258,0.155,0.163],[0.162,0.149,0.131]],"source":"clickhouse-datalake/results/t3a.small.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.027,0.012,0.011],[0.136,0.04,0.039],[0.224,0.082,0.081],[0.589,0.087,0.089],[1.012,0.594,0.594],[1.221,0.904,0.89],[0.139,0.042,0.042],[0.134,0.04,0.041],[1.049,0.696,0.696],[1.722,0.867,0.84],[0.84,0.242,0.24],[0.902,0.266,0.268],[1.367,0.985,0.928],[3.047,1.413,1.448],[1.472,1.085,1.088],[0.851,0.713,0.71],[3.807,2.814,2.836],[2.807,1.798,1.823],[7.253,5.189,5.199],[0.288,0.078,0.077],[10.625,1.237,1.242],[12.226,1.451,1.454],[23.365,2.726,2.706],[57.811,4.915,29.77],[3.063,0.504,0.495],[0.958,0.326,0.329],[2.727,0.504,0.499],[9.623,1.445,1.452],[10.808,10.614,10.535],[0.21,0.07,0.071],[2.684,0.947,0.95],[6.494,1.47,1.331],[11.971,10.937,11.299],[10.834,4.32,4.451],[10.773,4.294,4.343],[0.52,0.493,0.509],[0.257,0.115,0.118],[0.185,0.065,0.073],[0.193,0.046,0.048],[0.366,0.22,0.197],[0.15,0.03,0.031],[0.126,0.027,0.026],[0.121,0.023,0.023]],"source":"clickhouse-parquet-partitioned/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.021,0.015,0.012],[0.119,0.033,0.035],[0.153,0.059,0.06],[0.648,0.086,0.087],[1.136,0.403,0.412],[1.163,0.534,0.561],[0.104,0.031,0.036],[0.114,0.033,0.035],[1.011,0.503,0.504],[1.67,0.577,0.607],[0.854,0.211,0.209],[1.07,0.212,0.201],[1.428,0.672,0.659],[2.784,0.973,0.983],[1.379,0.773,0.76],[0.847,0.494,0.486],[3.341,1.845,1.855],[2.644,1.205,1.375],[6.242,3.799,3.786],[0.288,0.075,0.074],[10.557,1.118,1.123],[11.957,1.355,1.378],[22.963,2.417,2.406],[56.707,2.824,2.828],[3.022,0.355,0.352],[0.841,0.248,0.255],[2.734,0.345,0.349],[9.675,1.554,1.54],[8.662,5.644,5.657],[0.145,0.054,0.054],[2.63,0.572,0.582],[6.411,0.971,0.967],[7.07,4.487,4.502],[10.529,3.07,3.036],[10.56,3.107,3.037],[0.401,0.334,0.333],[0.242,0.114,0.115],[0.16,0.07,0.067],[0.183,0.048,0.046],[0.318,0.169,0.173],[0.133,0.028,0.028],[0.117,0.03,0.024],[0.116,0.022,0.023]],"source":"clickhouse-parquet-partitioned/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.137,0.03,0.03],[0.333,0.112,0.11],[0.609,0.269,0.27],[0.787,0.232,0.239],[2.11,1.751,1.749],[3.5,3.121,3.146],[0.35,0.12,0.12],[0.376,0.118,0.117],[2.574,2.227,2.225],[3.069,2.728,2.716],[1.331,0.781,0.778],[1.468,0.907,0.908],[3.496,3.059,3.026],[7.681,6.86,6.956],[4.152,3.695,3.732],[2.329,1.94,1.949],[12.686,12.23,12.285],[9.594,9.343,9.29],[25.301,24.425,25.997],[0.701,0.215,0.217],[9.541,4.977,5.062],[11.23,6.101,8.074],[21.871,21.829,21.921],[53.828,53.754,53.773],[2.841,1.98,1.811],[1.783,1.204,1.187],[2.916,1.779,1.78],[10,4.975,4.993],[42.436,41.672,41.853],[0.486,0.207,0.209],[4.152,3.396,3.4],[7.005,4.329,4.349],[30.329,29.764,31.298],[30.081,30.065,30.439],[29.631,30.584,29.971],[1.573,1.27,1.253],[0.522,0.229,0.222],[0.335,0.125,0.122],[0.372,0.09,0.095],[0.633,0.372,0.403],[0.258,0.063,0.063],[0.252,0.06,0.059],[0.252,0.054,0.054]],"source":"clickhouse-parquet-partitioned/results/c6a.large.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.056,0.047,0.05],[0.111,0.058,0.055],[0.157,0.077,0.075],[0.701,0.094,0.102],[1.052,0.269,0.27],[1.059,0.263,0.261],[0.111,0.069,0.06],[0.121,0.062,0.067],[1.062,0.374,0.386],[1.65,0.395,0.383],[0.841,0.183,0.194],[0.921,0.157,0.183],[1.213,0.278,0.266],[2.464,0.296,0.298],[1.109,0.276,0.285],[0.627,0.202,0.185],[2.559,0.416,0.417],[2.49,0.359,0.346],[4.559,0.838,0.822],[0.299,0.089,0.101],[10.202,0.392,0.378],[11.648,0.441,0.48],[22.308,0.663,0.705],[54.693,1.043,1.065],[2.862,0.156,0.176],[1.098,0.129,0.129],[3.122,0.158,0.164],[9.873,0.509,0.506],[8.527,1.267,1.287],[0.167,0.092,0.093],[2.577,0.214,0.206],[6.261,0.299,0.309],[5.09,1.012,1.035],[9.792,0.722,0.824],[9.789,0.803,0.856],[0.286,0.16,0.166],[0.247,0.139,0.147],[0.186,0.094,0.095],[0.199,0.088,0.087],[0.28,0.189,0.123],[0.127,0.075,0.07],[0.124,0.07,0.063],[0.118,0.056,0.054]],"source":"clickhouse-parquet-partitioned/results/c6a.metal.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.054,0.017,0.017],[0.198,0.065,0.062],[0.365,0.143,0.144],[0.8,0.131,0.134],[1.589,0.925,0.92],[1.739,1.582,1.586],[0.201,0.065,0.066],[0.206,0.064,0.065],[1.398,1.228,1.23],[2.186,1.483,1.476],[1.031,0.417,0.414],[1.252,0.483,0.482],[1.844,1.641,1.641],[3.928,2.439,2.451],[2.04,1.851,1.847],[1.248,1.034,1.032],[8.58,6.886,6.853],[5.235,4.988,5.131],[14.276,13.796,13.595],[0.404,0.116,0.117],[9.451,2.249,2.232],[11.221,2.723,2.756],[21.642,5.029,5.082],[53.641,54.013,54.047],[2.72,0.895,0.901],[0.921,0.599,0.597],[2.731,0.91,0.909],[9.639,2.276,2.283],[21.004,20.765,20.701],[0.321,0.112,0.115],[2.768,1.816,1.709],[6.68,2.472,2.516],[18.153,17.503,17.569],[18.909,14.178,14.483],[19.284,14.243,14.04],[0.986,0.801,0.794],[0.308,0.151,0.134],[0.225,0.08,0.076],[0.236,0.055,0.06],[0.401,0.231,0.24],[0.178,0.039,0.04],[0.161,0.035,0.035],[0.156,0.032,0.032]],"source":"clickhouse-parquet-partitioned/results/c6a.xlarge.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.074,0.057,0.041],[0.116,0.083,0.07],[0.668,0.086,0.082],[1.383,0.102,0.1],[1.604,0.434,0.43],[1.518,0.441,0.461],[0.107,0.071,0.079],[0.129,0.078,0.075],[1.442,0.38,0.399],[1.977,0.408,0.412],[1.165,0.232,0.22],[1.431,0.201,0.191],[1.709,0.273,0.277],[2.701,0.288,0.304],[1.268,0.234,0.257],[0.949,0.193,0.183],[2.962,0.346,0.336],[2.533,0.329,0.353],[4.538,0.582,0.574],[0.442,0.085,0.082],[10.658,0.368,0.347],[11.918,0.455,0.458],[22.48,0.657,0.647],[54.079,0.993,0.986],[2.752,0.167,0.173],[0.873,0.141,0.142],[2.748,0.174,0.171],[9.714,0.437,0.449],[8.184,0.638,0.631],[0.188,0.109,0.11],[2.582,0.235,0.223],[6.195,0.277,0.246],[4.845,0.723,0.726],[9.703,0.622,0.611],[9.728,0.61,0.612],[0.241,0.173,0.184],[0.254,0.16,0.158],[0.196,0.123,0.132],[0.188,0.095,0.124],[0.247,0.143,0.146],[0.146,0.074,0.081],[0.144,0.07,0.075],[0.115,0.073,0.073]],"source":"clickhouse-parquet-partitioned/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-28","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.017,0.017,0.021],[0.142,0.025,0.027],[0.194,0.044,0.04],[0.852,0.054,0.055],[1.112,0.19,0.19],[1.126,0.371,0.377],[0.144,0.029,0.031],[0.087,0.025,0.026],[0.879,0.255,0.26],[1.524,0.31,0.318],[0.839,0.124,0.15],[1.076,0.142,0.149],[1.365,0.369,0.36],[2.575,0.511,0.504],[1.163,0.406,0.402],[0.639,0.232,0.234],[2.804,0.843,0.946],[2.574,0.562,0.585],[5.054,1.597,1.603],[0.256,0.048,0.047],[10.937,0.471,0.454],[11.985,0.604,0.584],[23.649,0.966,0.985],[57.395,1.217,1.221],[2.949,0.22,0.205],[1.193,0.145,0.148],[3.248,0.217,0.213],[10.506,0.476,0.492],[8.858,3.07,3.046],[0.133,0.047,0.051],[2.824,0.353,0.339],[6.65,0.454,0.461],[5.597,1.677,1.601],[10.525,1.351,1.339],[10.545,1.304,1.295],[0.247,0.188,0.188],[0.176,0.085,0.09],[0.126,0.06,0.055],[0.158,0.042,0.038],[0.23,0.134,0.129],[0.103,0.029,0.024],[0.094,0.028,0.031],[0.087,0.021,0.022]],"source":"clickhouse-parquet-partitioned/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-08-28","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.047,0.042,0.04],[0.104,0.066,0.048],[0.595,0.069,0.059],[1.332,0.06,0.064],[1.441,0.25,0.247],[1.597,0.302,0.291],[0.104,0.055,0.057],[0.103,0.073,0.055],[1.274,0.259,0.268],[1.988,0.279,0.272],[1.121,0.164,0.163],[1.334,0.122,0.133],[1.546,0.223,0.173],[2.692,0.312,0.247],[1.118,0.205,0.186],[0.822,0.131,0.141],[2.916,0.293,0.334],[2.427,0.315,0.297],[4.469,0.496,0.498],[0.344,0.067,0.061],[10.59,0.321,0.338],[11.701,0.452,0.463],[22.38,0.598,0.573],[54.429,1.078,0.966],[2.734,0.138,0.129],[0.85,0.131,0.114],[2.731,0.134,0.131],[9.698,0.446,0.41],[8.038,0.497,0.559],[0.223,0.116,0.115],[2.565,0.175,0.174],[6.188,0.229,0.204],[4.854,0.726,0.784],[9.745,0.489,0.527],[9.716,0.504,0.59],[0.262,0.109,0.105],[0.207,0.101,0.095],[0.172,0.104,0.082],[0.167,0.071,0.076],[0.196,0.105,0.109],[0.118,0.069,0.058],[0.101,0.064,0.056],[0.091,0.063,0.053]],"source":"clickhouse-parquet-partitioned/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.036,0.012,0.012],[0.188,0.039,0.039],[0.307,0.082,0.083],[0.51,0.093,0.093],[0.826,0.611,0.604],[1.059,0.882,0.885],[0.164,0.045,0.042],[0.178,0.04,0.041],[0.98,0.754,0.745],[1.621,0.876,0.87],[0.764,0.212,0.21],[0.816,0.237,0.241],[1.23,0.909,0.918],[2.84,1.388,1.359],[1.316,1.056,1.06],[1.04,0.753,0.75],[3.665,2.933,2.969],[2.57,1.892,1.897],[7.142,5.433,5.453],[0.484,0.086,0.089],[10.216,1.212,1.209],[12.065,1.484,1.466],[23.088,2.863,2.791],[57.028,7.87,13.206],[3.012,0.485,0.478],[0.951,0.304,0.31],[3.007,0.49,0.487],[10.485,1.702,1.677],[10.954,10.552,10.591],[0.359,0.074,0.072],[2.954,0.921,0.925],[7.007,1.353,1.46],[13.261,12.609,12.892],[11.708,8.647,8.714],[11.007,4.666,8.416],[0.648,0.486,0.481],[0.276,0.115,0.135],[0.183,0.067,0.073],[0.218,0.045,0.046],[0.397,0.201,0.194],[0.158,0.032,0.032],[0.125,0.026,0.027],[0.126,0.024,0.024]],"source":"clickhouse-parquet-partitioned/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.017,0.019,0.02],[0.104,0.035,0.037],[0.136,0.061,0.059],[0.475,0.083,0.094],[0.607,0.407,0.41],[0.944,0.514,0.5],[0.106,0.042,0.04],[0.112,0.038,0.044],[0.855,0.516,0.503],[1.513,0.591,0.574],[0.695,0.193,0.188],[0.768,0.188,0.193],[1.056,0.642,0.657],[2.568,0.977,0.988],[1.149,0.74,0.727],[0.679,0.489,0.492],[3.074,1.788,1.808],[2.345,1.127,1.116],[5.915,3.757,3.793],[0.193,0.08,0.082],[9.76,1.102,1.111],[11.556,1.331,1.321],[22.267,2.386,2.407],[55.1,2.779,2.781],[2.838,0.334,0.346],[0.86,0.246,0.247],[2.818,0.338,0.349],[9.972,1.545,1.529],[8.614,5.388,5.435],[0.144,0.061,0.059],[2.716,0.552,0.563],[6.557,0.919,0.927],[7.114,4.459,4.469],[10.834,3.138,3.095],[10.833,3.116,3.077],[0.397,0.336,0.336],[0.235,0.105,0.109],[0.143,0.067,0.065],[0.178,0.049,0.043],[0.297,0.181,0.174],[0.115,0.032,0.031],[0.099,0.039,0.022],[0.095,0.023,0.025]],"source":"clickhouse-parquet-partitioned/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.105,0.031,0.031],[0.317,0.113,0.115],[0.606,0.286,0.287],[0.787,0.238,0.237],[2.2,1.885,1.884],[3.367,3.085,3.099],[0.34,0.123,0.122],[0.33,0.116,0.116],[2.723,2.403,2.436],[3.236,2.958,2.985],[1.201,0.679,0.683],[1.319,0.796,0.788],[3.362,2.986,3.001],[7.471,6.944,6.983],[4.001,3.594,3.596],[2.4,2.037,2.003],[12.213,12.036,11.922],[9.582,9.007,9.42],[24.811,23.127,24.145],[0.687,0.217,0.215],[9.494,3.314,3.275],[11.38,4.251,8.073],[21.865,21.742,21.733],[53.886,53.706,53.725],[2.759,1.606,1.606],[1.642,1.007,0.997],[2.725,1.598,1.602],[9.708,3.791,3.825],[41.913,41.013,40.957],[0.499,0.218,0.218],[3.946,3.227,3.204],[7.011,4.212,4.192],[30.125,29.704,30.505],[27.077,26.628,27.052],[27.105,27.213,27.573],[1.638,1.352,1.34],[0.437,0.219,0.216],[0.299,0.124,0.12],[0.33,0.09,0.092],[0.577,0.356,0.353],[0.256,0.067,0.065],[0.237,0.062,0.063],[0.227,0.056,0.059]],"source":"clickhouse-parquet-partitioned/results/c6a.large.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.138,0.044,0.04],[0.272,0.076,0.071],[0.457,0.072,0.087],[0.837,0.104,0.109],[1.087,0.269,0.285],[1.44,0.268,0.25],[0.25,0.063,0.072],[0.103,0.071,0.083],[1.02,0.394,0.385],[1.646,0.397,0.404],[0.818,0.195,0.2],[1.116,0.174,0.188],[1.329,0.288,0.27],[2.452,0.323,0.326],[1.094,0.286,0.311],[0.592,0.204,0.229],[2.568,0.449,0.441],[2.473,0.377,0.362],[4.644,0.868,0.89],[0.286,0.1,0.106],[15.022,0.388,0.394],[11.671,0.452,0.461],[22.214,0.718,0.729],[57.412,1.075,1.064],[2.858,0.166,0.173],[1.154,0.165,0.149],[3.173,0.184,0.188],[9.687,0.544,0.544],[8.336,1.148,1.052],[0.15,0.091,0.108],[2.576,0.238,0.235],[6.217,0.331,0.328],[5.26,1.07,1.104],[9.875,0.956,0.757],[9.867,0.888,0.803],[0.223,0.167,0.175],[0.214,0.146,0.137],[0.152,0.099,0.125],[0.163,0.099,0.086],[0.279,0.217,0.205],[0.115,0.07,0.07],[0.123,0.071,0.059],[0.118,0.057,0.056]],"source":"clickhouse-parquet-partitioned/results/c6a.metal.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.083,0.017,0.018],[0.323,0.062,0.062],[0.616,0.145,0.146],[0.984,0.134,0.133],[1.271,0.93,0.941],[1.821,1.533,1.524],[0.354,0.069,0.067],[0.181,0.065,0.065],[1.405,1.276,1.247],[2.152,1.527,1.529],[0.986,0.343,0.348],[1.269,0.411,0.417],[1.832,1.556,1.565],[3.786,2.339,2.348],[1.897,1.749,1.744],[1.244,1.03,1.039],[5.218,6.497,6.614],[3.428,4.944,4.98],[13.433,13.07,13.336],[0.359,0.12,0.121],[9.702,1.734,1.764],[11.188,2.148,2.135],[21.814,4.158,4.158],[53.66,53.827,53.85],[2.718,0.825,0.827],[0.812,0.525,0.517],[2.74,0.827,0.827],[9.657,2.043,2.034],[20.803,20.508,20.51],[0.301,0.119,0.117],[2.723,1.601,1.599],[6.663,2.494,2.361],[17.743,17.143,16.921],[19.645,13.871,14.202],[18.919,14.405,14.301],[0.951,0.817,0.817],[0.285,0.135,0.136],[0.187,0.079,0.081],[0.231,0.059,0.059],[0.378,0.225,0.223],[0.164,0.041,0.04],[0.155,0.035,0.035],[0.146,0.033,0.031]],"source":"clickhouse-parquet-partitioned/results/c6a.xlarge.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.084,0.062,0.056],[0.16,0.091,0.086],[0.31,0.093,0.096],[0.623,0.119,0.123],[1.126,0.475,0.448],[1.212,0.476,0.473],[0.215,0.086,0.098],[0.233,0.099,0.089],[1.022,0.42,0.399],[1.645,0.43,0.431],[1.058,0.251,0.242],[0.914,0.208,0.216],[1.083,0.268,0.283],[2.421,0.334,0.299],[1.132,0.263,0.235],[0.691,0.194,0.213],[2.437,0.366,0.385],[2.425,0.369,0.372],[4.42,0.612,0.623],[0.611,0.113,0.103],[9.855,0.408,0.39],[11.573,0.465,0.476],[22.352,0.624,0.638],[54.422,1.012,1.013],[2.846,0.192,0.181],[0.935,0.158,0.17],[2.842,0.186,0.192],[10.069,0.513,0.457],[8.344,0.662,0.648],[0.493,0.117,0.119],[2.661,0.231,0.239],[6.356,0.303,0.291],[5.005,0.785,0.795],[9.979,0.685,0.7],[9.979,0.671,0.641],[0.636,0.175,0.185],[0.298,0.16,0.182],[0.249,0.133,0.135],[0.335,0.132,0.142],[0.406,0.155,0.156],[0.193,0.077,0.082],[0.153,0.071,0.084],[0.199,0.074,0.092]],"source":"clickhouse-parquet-partitioned/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.022,0.013,0.014],[0.092,0.023,0.034],[0.139,0.048,0.041],[1.023,0.052,0.055],[1.151,0.199,0.186],[1.284,0.341,0.355],[0.131,0.031,0.024],[0.108,0.026,0.027],[0.924,0.251,0.276],[1.637,0.299,0.307],[0.895,0.12,0.129],[1.253,0.132,0.137],[1.486,0.355,0.334],[2.591,0.477,0.483],[1.267,0.377,0.398],[0.685,0.218,0.212],[2.77,0.759,0.879],[2.622,0.573,0.53],[5.082,1.523,1.518],[0.29,0.044,0.05],[10.643,0.471,0.481],[12.12,0.567,0.563],[22.99,0.936,0.941],[56.743,1.22,1.199],[3.03,0.187,0.186],[1.24,0.131,0.131],[3.35,0.188,0.193],[9.656,0.485,0.486],[8.301,2.96,2.954],[0.144,0.056,0.055],[2.589,0.316,0.308],[6.223,0.417,0.42],[5.28,1.656,1.613],[9.783,1.25,1.223],[9.775,1.24,1.262],[0.301,0.173,0.179],[0.193,0.074,0.076],[0.131,0.041,0.042],[0.157,0.032,0.032],[0.26,0.119,0.118],[0.095,0.021,0.021],[0.088,0.024,0.018],[0.09,0.018,0.018]],"source":"clickhouse-parquet-partitioned/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.091,0.054,0.054],[0.297,0.077,0.075],[0.794,0.072,0.075],[1.541,0.086,0.093],[1.682,0.371,0.379],[2.076,0.354,0.359],[0.315,0.078,0.077],[0.329,0.081,0.075],[1.959,0.3,0.301],[2.627,0.339,0.315],[1.806,0.184,0.176],[1.82,0.148,0.167],[2.001,0.214,0.221],[3.377,0.243,0.261],[1.994,0.207,0.207],[1.616,0.181,0.171],[3.435,0.348,0.329],[2.287,0.324,0.354],[4.237,0.517,0.512],[0.197,0.069,0.067],[9.676,0.334,0.342],[11.262,0.436,0.429],[21.702,0.603,0.608],[53.63,1.038,0.972],[2.739,0.148,0.156],[0.832,0.145,0.147],[2.741,0.155,0.157],[9.686,0.423,0.384],[8.036,0.519,0.524],[0.19,0.124,0.132],[2.567,0.197,0.204],[6.198,0.267,0.266],[4.873,0.735,0.717],[9.697,0.543,0.534],[9.711,0.572,0.674],[0.183,0.133,0.155],[0.181,0.119,0.114],[0.145,0.089,0.096],[0.189,0.084,0.066],[0.198,0.103,0.112],[0.114,0.07,0.064],[0.101,0.065,0.069],[0.111,0.067,0.068]],"source":"clickhouse-parquet-partitioned/results/c8g.metal-48xl.json"}
,{"system":"ClickHouse (Parquet, partitioned)","date":"2025-07-12","machine":"t3a.small","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14737666736,"result":[[0.178,0.08,0.08],[1.087,0.782,0.775],[2.144,1.636,1.628],[2.06,1.168,1.186],[4.608,4.006,3.987],[7.227,6.818,6.846],[1.004,0.724,0.722],[1.106,0.81,0.798],[6.378,5.53,5.668],[8.707,7.711,7.806],[4.415,3.423,3.367],[4.339,4.222,4.285],[10.283,9.765,9.636],[16.495,16.791,16.338],[11.78,11.118,10.986],[5.891,5.209,5.48],[25.666,25.841,26.052],[19.687,20.016,19.392],[49.027,50.246,48.995],[1.769,1.14,1.092],[21.75,22.328,21.735],[25.563,26.695,27.03],[48.788,50.053,49.689],[191.323,191.944,192.37],[7.181,5.178,5.287],[4.642,3.646,3.635],[6.991,5.157,5.19],[23.335,23.741,23.526],[141.18,141.099,140.328],[1.433,1.028,1.018],[10.643,9.13,10.146],[17.062,17.496,16.92],[60.009,59.135,59.6],[60.316,59.906,60.131],[60.427,61.093,59.665],[3.518,3.019,3.02],[1.068,0.661,0.729],[0.65,0.46,0.453],[0.901,0.539,0.556],[1.554,1.093,1.102],[0.456,0.256,0.259],[0.448,0.255,0.251],[0.435,0.242,0.244]],"source":"clickhouse-parquet-partitioned/results/t3a.small.json"}
-,{"system":"ClickHouse (Parquet, single)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.038,0.026,0.025],[0.157,0.053,0.052],[0.241,0.095,0.096],[0.359,0.122,0.122],[0.715,0.62,0.615],[1.022,0.931,0.935],[0.156,0.055,0.057],[0.161,0.055,0.056],[0.829,0.725,0.736],[1.226,0.861,0.87],[0.536,0.286,0.289],[0.578,0.31,0.314],[1.106,0.967,0.981],[2.436,1.413,1.434],[1.299,1.105,1.106],[0.858,0.74,0.74],[3.095,3.952,3.852],[2.09,2.813,2.816],[6.325,8.2,8.074],[0.285,0.124,0.117],[9.539,1.349,1.356],[11.221,2.109,2.083],[21.871,4.12,4.115],[54.737,45.161,28.963],[2.535,0.574,0.556],[0.77,0.351,0.359],[2.541,0.556,0.558],[9.683,1.908,1.889],[11.327,11.137,11.118],[0.219,0.092,0.087],[2.451,0.986,0.987],[6.172,1.388,1.372],[13.069,12.455,11.382],[11.031,8.422,8.464],[11.012,8.472,8.377],[0.538,0.436,0.435],[0.286,0.117,0.125],[0.219,0.08,0.085],[0.236,0.067,0.065],[0.288,0.152,0.151],[0.162,0.046,0.045],[0.148,0.043,0.041],[0.143,0.038,0.038]],"source":"clickhouse-parquet/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (Parquet, single)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.036,0.026,0.026],[0.119,0.053,0.055],[0.231,0.098,0.098],[0.359,0.121,0.122],[0.698,0.605,0.602],[0.975,0.901,0.897],[0.138,0.059,0.058],[0.151,0.056,0.057],[0.802,0.717,0.717],[1.243,0.86,0.864],[0.54,0.231,0.227],[0.566,0.258,0.256],[1.012,0.926,0.921],[2.452,1.336,1.328],[1.211,1.028,1.028],[0.811,0.718,0.719],[3.072,3.712,3.695],[2.119,2.726,2.733],[6.334,7.757,7.85],[0.267,0.117,0.117],[9.854,1.257,1.248],[11.566,1.84,1.838],[22.58,3.725,3.689],[56.382,51.485,46.054],[2.598,0.503,0.507],[0.766,0.32,0.323],[2.614,0.506,0.513],[9.967,1.743,1.708],[10.819,11.125,11.129],[0.209,0.086,0.087],[2.496,0.911,0.914],[6.327,1.298,1.31],[11.782,10.513,10.554],[11.131,7.989,7.967],[11.123,8.075,8.127],[0.529,0.438,0.442],[0.269,0.127,0.12],[0.208,0.084,0.081],[0.229,0.067,0.068],[0.286,0.146,0.148],[0.157,0.048,0.044],[0.142,0.041,0.047],[0.137,0.04,0.039]],"source":"clickhouse-parquet/results/c6a.2xlarge.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.037,0.025,0.026],[0.144,0.05,0.049],[0.191,0.07,0.071],[0.373,0.137,0.138],[0.53,0.426,0.442],[0.847,0.526,0.542],[0.142,0.054,0.052],[0.155,0.049,0.054],[0.746,0.549,0.522],[1.245,0.594,0.632],[0.625,0.232,0.228],[0.632,0.233,0.234],[0.955,0.667,0.663],[2.327,0.956,0.968],[1.041,0.732,0.732],[0.629,0.517,0.522],[2.794,1.816,1.832],[2.096,1.144,1.143],[5.562,5.758,5.704],[0.244,0.123,0.125],[9.627,1.232,1.218],[11.241,1.458,1.445],[21.869,2.692,2.712],[54.67,3.187,3.188],[2.558,0.38,0.38],[0.779,0.289,0.288],[2.552,0.373,0.377],[9.722,1.473,1.468],[8.288,5.41,5.425],[0.188,0.068,0.07],[2.415,0.591,0.585],[6.064,0.982,0.986],[6.692,4.496,4.498],[10.702,3.202,3.205],[10.703,3.203,3.205],[0.46,0.354,0.352],[0.28,0.127,0.125],[0.217,0.088,0.084],[0.243,0.069,0.071],[0.288,0.139,0.139],[0.167,0.05,0.052],[0.155,0.042,0.04],[0.151,0.039,0.038]],"source":"clickhouse-parquet/results/c6a.4xlarge.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-07-11","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.064,0.054,0.055],[0.321,0.145,0.148],[0.737,0.353,0.354],[1.12,0.361,0.355],[2.415,1.877,1.907],[4.318,3.753,3.74],[0.304,0.131,0.131],[0.32,0.153,0.153],[3.039,2.454,2.48],[3.845,2.998,3],[2.035,1.27,1.272],[2.245,1.423,1.42],[4.375,3.724,3.761],[8.829,7.762,7.717],[5.075,4.421,4.462],[2.683,2.093,2.103],[14.571,13.871,13.808],[11.722,10.931,10.792],[30.455,29.644,29.253],[1.011,0.328,0.328],[14.539,8.772,9.303],[17.188,12.299,11.525],[31.724,31.504,32.779],[92.132,94.263,93.28],[4.192,2.432,2.377],[2.706,1.795,1.832],[4.168,2.458,2.412],[15.221,10.097,9.357],[83.796,83.98,83.704],[0.594,0.307,0.308],[4.993,3.498,3.45],[7.681,4.622,4.608],[34.258,33.929,33.787],[36.487,36.581,37.611],[36.79,37.659,37.33],[1.858,1.393,1.403],[0.521,0.362,0.349],[0.341,0.224,0.244],[0.469,0.266,0.24],[0.92,0.635,0.631],[0.234,0.098,0.099],[0.208,0.088,0.088],[0.21,0.088,0.089]],"source":"clickhouse-parquet/results/c6a.large.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-08-31","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.037,0.026,0.027],[0.149,0.068,0.07],[0.193,0.098,0.083],[0.441,0.104,0.096],[0.539,0.28,0.284],[0.899,0.256,0.259],[0.146,0.068,0.067],[0.159,0.073,0.072],[0.876,0.401,0.397],[1.349,0.425,0.418],[0.618,0.216,0.195],[0.636,0.187,0.199],[0.878,0.245,0.255],[2.147,0.301,0.328],[0.933,0.246,0.258],[0.426,0.193,0.187],[2.212,0.486,0.468],[2.142,0.363,0.352],[4.2,1.009,0.989],[0.252,0.094,0.092],[9.619,0.439,0.431],[11.379,0.673,0.782],[22.089,1.032,1.07],[54.767,1.323,2.785],[2.565,0.165,0.17],[0.804,0.122,0.175],[2.568,0.163,0.163],[9.805,0.635,0.634],[8.118,0.913,0.909],[0.214,0.091,0.096],[2.363,0.233,0.225],[5.894,0.358,0.333],[4.778,1.224,1.327],[9.903,0.875,0.75],[9.949,0.862,0.801],[0.347,0.167,0.178],[0.291,0.136,0.139],[0.219,0.115,0.111],[0.254,0.084,0.087],[0.282,0.128,0.133],[0.169,0.065,0.061],[0.155,0.052,0.054],[0.151,0.049,0.048]],"source":"clickhouse-parquet/results/c6a.metal.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-07-11","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.067,0.057,0.056],[0.22,0.109,0.11],[0.444,0.222,0.218],[0.669,0.233,0.234],[1.304,1.011,1.021],[2.246,1.963,1.959],[0.214,0.103,0.107],[0.226,0.116,0.113],[1.675,1.378,1.38],[2.055,1.676,1.684],[1.144,0.727,0.721],[1.239,0.817,0.816],[2.402,2.049,2.049],[3.455,2.92,2.913],[2.651,2.316,2.329],[1.451,1.138,1.146],[6.003,5.673,5.687],[4.174,3.771,3.786],[16.678,15.931,16.41],[0.606,0.213,0.213],[9.6,4.95,4.776],[11.307,5.822,5.68],[22.105,11.375,11.122],[56.565,56.536,56.43],[2.603,1.31,1.329],[1.477,0.991,1.034],[2.606,1.308,1.327],[9.805,5.661,5.243],[39.92,39.596,39.641],[0.384,0.202,0.201],[2.704,1.885,1.872],[6.448,2.777,2.774],[19.634,18.895,19.104],[21.127,17.688,18.169],[20.482,17.929,17.79],[1.154,0.911,0.909],[0.415,0.222,0.223],[0.247,0.15,0.178],[0.31,0.201,0.181],[0.539,0.341,0.342],[0.193,0.084,0.084],[0.178,0.081,0.081],[0.193,0.083,0.082]],"source":"clickhouse-parquet/results/c6a.xlarge.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.037,0.026,0.026],[0.136,0.07,0.071],[0.162,0.079,0.079],[0.358,0.092,0.095],[0.663,0.426,0.423],[1.091,0.425,0.434],[0.124,0.067,0.065],[0.14,0.07,0.069],[0.858,0.382,0.392],[1.359,0.394,0.4],[0.619,0.237,0.243],[0.633,0.201,0.201],[0.897,0.284,0.262],[2.155,0.295,0.317],[0.906,0.262,0.257],[0.416,0.192,0.2],[2.167,0.373,0.365],[2.13,0.38,0.352],[4.063,0.608,0.556],[0.245,0.086,0.081],[9.633,0.365,0.375],[11.493,0.6,0.611],[22.041,0.946,0.953],[54.699,1.123,1.123],[2.54,0.182,0.159],[0.801,0.134,0.13],[2.546,0.187,0.16],[9.774,0.64,1.605],[8.207,0.638,0.635],[0.182,0.097,0.102],[2.364,0.232,0.257],[5.857,0.296,0.298],[4.538,0.777,0.747],[9.813,0.613,0.64],[9.828,0.632,0.682],[0.279,0.17,0.175],[0.273,0.161,0.156],[0.201,0.13,0.104],[0.206,0.088,0.083],[0.279,0.129,0.134],[0.167,0.063,0.064],[0.163,0.058,0.057],[0.15,0.048,0.049]],"source":"clickhouse-parquet/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (Parquet, single)","date":"2025-08-28","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.031,0.021,0.021],[0.111,0.041,0.04],[0.158,0.053,0.055],[0.347,0.062,0.064],[0.411,0.21,0.214],[0.781,0.336,0.343],[0.114,0.04,0.041],[0.12,0.044,0.041],[0.649,0.261,0.261],[1.155,0.322,0.313],[0.542,0.183,0.182],[0.58,0.182,0.187],[0.826,0.333,0.333],[2.131,0.473,0.48],[0.899,0.383,0.377],[0.43,0.23,0.239],[2.285,0.853,0.818],[2.034,0.563,0.558],[4.432,2.726,2.651],[0.233,0.061,0.06],[9.561,0.534,0.532],[11.197,0.986,1.003],[21.822,1.795,1.753],[54.601,1.57,1.59],[2.53,0.255,0.254],[0.752,0.158,0.161],[2.526,0.252,0.254],[9.672,0.746,0.756],[8.032,2.878,2.867],[0.155,0.062,0.061],[2.333,0.353,0.356],[5.871,0.496,0.497],[5.008,1.699,1.657],[9.918,1.393,1.381],[9.924,1.396,1.379],[0.292,0.182,0.192],[0.23,0.092,0.097],[0.173,0.066,0.065],[0.192,0.052,0.052],[0.219,0.083,0.089],[0.133,0.037,0.037],[0.121,0.033,0.033],[0.117,0.032,0.031]],"source":"clickhouse-parquet/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse (Parquet, single)","date":"2025-08-28","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.035,0.024,0.024],[0.114,0.046,0.045],[0.159,0.059,0.054],[0.368,0.066,0.073],[0.538,0.228,0.253],[0.933,0.308,0.251],[0.111,0.044,0.045],[0.126,0.057,0.059],[0.788,0.286,0.269],[1.304,0.283,0.288],[0.585,0.157,0.176],[0.639,0.137,0.141],[0.876,0.171,0.178],[2.127,0.254,0.32],[0.928,0.225,0.204],[0.42,0.159,0.128],[2.165,0.317,0.301],[2.191,0.408,0.325],[4.061,0.496,0.627],[0.278,0.067,0.069],[9.76,0.362,0.383],[11.553,0.48,0.499],[22.402,0.812,0.809],[55.782,1.142,1.076],[2.61,0.156,0.16],[0.817,0.099,0.107],[2.612,0.152,0.156],[9.978,0.485,0.469],[8.254,0.522,0.536],[0.206,0.1,0.1],[2.393,0.172,0.18],[5.956,0.265,0.294],[4.491,0.642,0.686],[9.963,0.622,0.607],[9.907,0.557,0.586],[0.278,0.12,0.111],[0.248,0.109,0.11],[0.178,0.08,0.081],[0.201,0.06,0.061],[0.234,0.097,0.095],[0.14,0.049,0.048],[0.129,0.042,0.043],[0.124,0.042,0.041]],"source":"clickhouse-parquet/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse (Parquet, single)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.039,0.022,0.022],[0.19,0.04,0.041],[0.214,0.053,0.054],[0.38,0.062,0.063],[0.396,0.205,0.203],[0.747,0.323,0.322],[0.198,0.044,0.045],[0.101,0.043,0.041],[0.635,0.264,0.293],[1.132,0.323,0.322],[0.524,0.149,0.145],[0.564,0.149,0.15],[0.815,0.31,0.305],[2.097,0.448,0.446],[0.869,0.368,0.358],[0.415,0.238,0.237],[2.264,0.783,0.787],[2.004,0.538,0.537],[4.399,2.567,2.6],[0.209,0.059,0.059],[9.568,0.524,0.527],[11.179,0.945,0.949],[22.581,1.712,1.71],[54.609,1.604,1.601],[2.511,0.228,0.223],[0.73,0.149,0.149],[2.511,0.228,0.229],[9.644,0.746,0.745],[8.019,2.897,2.903],[0.126,0.062,0.059],[2.318,0.334,0.334],[5.864,0.47,0.473],[4.97,1.703,1.697],[9.852,1.336,1.329],[9.878,1.339,1.338],[0.268,0.188,0.192],[0.226,0.087,0.09],[0.166,0.062,0.059],[0.193,0.05,0.05],[0.215,0.083,0.084],[0.129,0.038,0.038],[0.114,0.033,0.032],[0.112,0.03,0.03]],"source":"clickhouse-parquet/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse (Parquet, single)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.035,0.025,0.025],[0.118,0.077,0.079],[0.121,0.058,0.067],[0.324,0.063,0.066],[0.58,0.338,0.344],[0.865,0.364,0.345],[0.085,0.057,0.061],[0.121,0.076,0.082],[0.762,0.298,0.287],[1.243,0.307,0.311],[0.539,0.165,0.172],[0.571,0.148,0.152],[0.807,0.215,0.218],[2.07,0.228,0.269],[0.882,0.21,0.2],[0.394,0.159,0.158],[2.096,0.343,0.336],[2.078,0.329,0.312],[3.96,0.656,0.552],[0.187,0.059,0.074],[9.629,0.361,0.36],[11.345,0.481,0.496],[21.902,0.818,0.801],[54.704,1.082,1.083],[2.516,0.121,0.14],[0.739,0.103,0.112],[2.506,0.151,0.133],[9.7,0.439,0.447],[8.034,0.507,0.512],[0.178,0.11,0.108],[2.304,0.178,0.198],[5.815,0.232,0.247],[4.485,0.814,0.922],[9.725,0.627,0.685],[9.738,0.578,0.667],[0.212,0.132,0.12],[0.206,0.112,0.108],[0.196,0.084,0.088],[0.205,0.068,0.074],[0.247,0.114,0.095],[0.139,0.057,0.06],[0.126,0.056,0.052],[0.124,0.052,0.05]],"source":"clickhouse-parquet/results/c8g.metal-48xl.json"}
,{"system":"ClickHouse (Parquet, single)","date":"2025-07-12","machine":"t3a.small","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless","ClickHouse derivative"],"load_time":0,"data_size":14779976446,"result":[[0.086,0.066,0.07],[0.464,0.282,0.286],[1.092,0.667,0.613],[1.569,0.638,0.624],[4.116,3.475,3.493],[6.992,6.402,6.335],[0.399,0.203,0.208],[0.491,0.294,0.318],[5.271,4.708,4.713],[6.614,5.831,5.613],[3.238,2.338,2.372],[3.408,2.736,2.621],[10.23,9.617,9.248],[15.713,15.919,15.857],[11.378,10.727,10.366],[5.882,5.459,5.333],[25.913,26.478,26.165],[19.118,19.64,19.231],[50.54,50.812,51.36],[1.411,0.669,0.644],[23.08,23.915,23.634],[27.426,25.673,27.726],[49.487,49.964,51.739],[146.869,145.467,145.619],[6.314,4.272,4.401],[4.507,3.217,3.243],[6.189,4.293,4.318],[25.832,25.559,24.456],[139.389,139.255,140.198],[0.829,0.5,0.51],[8.429,7.865,7.256],[15.066,15.189,15.451],[58.929,59.028,58.688],[61.234,59.883,60.557],[61.271,61.052,61.983],[2.944,2.446,2.451],[0.824,0.615,0.647],[0.705,0.502,0.415],[0.642,0.458,0.475],[1.316,0.981,1.106],[0.35,0.204,0.209],[0.33,0.185,0.193],[0.37,0.19,0.202]],"source":"clickhouse-parquet/results/t3a.small.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":283,"data_size":15255081534,"result":[[0.002,0.002,0.001],[0.047,0.009,0.009],[0.23,0.041,0.04],[0.876,0.063,0.057],[1.153,0.53,0.525],[1.312,0.635,0.578],[0.028,0.014,0.014],[0.026,0.012,0.011],[0.717,0.65,0.64],[0.849,0.74,0.735],[0.247,0.158,0.158],[0.516,0.187,0.202],[1.373,0.626,0.543],[1.744,0.952,0.883],[1.178,0.691,0.696],[0.572,0.488,0.473],[2.228,1.572,1.584],[1.829,0.621,0.602],[4.436,2.678,2.629],[0.165,0.003,0.003],[10.604,0.46,0.422],[11.567,0.11,0.099],[14.491,0.645,0.645],[1.176,0.081,0.074],[1.56,0.021,0.017],[1.417,0.209,0.205],[1.395,0.02,0.02],[0.891,0.156,0.154],[11.249,10.643,10.673],[0.069,0.042,0.042],[0.953,0.49,0.442],[3.609,0.592,0.593],[10.876,9.838,9.898],[16.272,8.099,7.777],[15.327,7.595,6.766],[0.392,0.332,0.335],[0.069,0.054,0.05],[0.038,0.025,0.025],[0.042,0.019,0.024],[0.126,0.091,0.095],[0.029,0.014,0.014],[0.024,0.012,0.011],[0.02,0.01,0.012]],"source":"clickhouse-tencent/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":232,"data_size":15258871704,"result":[[0.002,0.002,0.002],[0.02,0.007,0.007],[0.045,0.021,0.021],[0.461,0.03,0.029],[0.918,0.401,0.399],[0.658,0.417,0.403],[0.017,0.01,0.011],[0.015,0.009,0.009],[0.519,0.456,0.447],[0.664,0.507,0.503],[0.195,0.143,0.136],[0.436,0.151,0.137],[1.338,0.441,0.45],[1.645,0.652,0.68],[0.928,0.49,0.493],[0.655,0.377,0.393],[1.916,1.226,1.224],[1.547,0.498,0.493],[4.037,2.152,2.234],[0.072,0.003,0.003],[10.195,0.32,0.316],[11.224,0.114,0.11],[14.185,0.692,0.703],[0.858,0.071,0.058],[1.499,0.016,0.015],[1.364,0.181,0.18],[1.273,0.016,0.015],[0.878,0.087,0.086],[8.975,5.41,5.37],[0.061,0.03,0.028],[0.921,0.325,0.31],[3.665,0.538,0.553],[5.354,3.847,3.865],[11.232,2.342,2.294],[10.982,2.301,2.277],[0.3,0.274,0.248],[0.097,0.057,0.059],[0.048,0.035,0.036],[0.063,0.022,0.025],[0.165,0.104,0.107],[0.034,0.016,0.014],[0.028,0.013,0.012],[0.021,0.012,0.01]],"source":"clickhouse-tencent/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":406,"data_size":15224660889,"result":[[0.006,0.002,0.002],[0.157,0.052,0.048],[0.484,0.381,0.337],[0.843,0.382,0.455],[3.829,2.721,2.822],[4.828,3.87,3.873],[0.125,0.069,0.072],[0.128,0.055,0.057],[5.01,3.706,3.915],[5.273,4.883,4.133],[1.21,0.712,0.695],[1.173,0.819,0.805],[3.379,2.328,2.639],[8.164,8.138,8.556],[3.798,3.05,3.024],[2.304,1.899,1.821],[11.884,12.495,11.846],[3.116,2.726,2.713],[21.904,22.463,21.498],[0.446,0.003,0.003],[10.064,3.484,3.258],[14.179,0.969,0.638],[18.122,6.361,7.669],[2.001,0.173,0.172],[1.128,0.063,0.049],[1.498,1.011,0.968],[1.182,0.065,0.057],[1.108,0.767,0.739],[55.46,43.14,42.308],[0.197,0.113,0.113],[1.706,1.431,1.404],[3.669,4.041,2.254],[28.719,29.593,29.444],[24.459,24.343,24.517],[24.393,25.055,24.694],[1.269,1.142,1.038],[0.18,0.113,0.113],[0.084,0.059,0.059],[0.102,0.043,0.045],[0.333,0.23,0.234],[0.049,0.022,0.023],[0.044,0.019,0.019],[0.035,0.019,0.023]],"source":"clickhouse-tencent/results/c6a.large.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":8,"data_size":15260192291,"result":[[0.003,0.002,0.001],[0.022,0.011,0.009],[0.104,0.013,0.013],[0.276,0.015,0.015],[0.301,0.091,0.08],[1.173,0.111,0.11],[0.022,0.011,0.009],[0.024,0.014,0.013],[0.692,0.291,0.299],[0.949,0.302,0.309],[0.379,0.097,0.094],[0.449,0.103,0.105],[1.196,0.119,0.119],[2.001,0.17,0.172],[1.237,0.131,0.14],[0.426,0.087,0.081],[2.095,0.218,0.225],[1.742,0.076,0.072],[3.649,0.391,0.38],[0.145,0.003,0.002],[9.729,0.072,0.086],[11.37,0.039,0.037],[14.385,0.142,0.128],[1.587,0.055,0.05],[1.45,0.022,0.021],[1.283,0.038,0.039],[1.589,0.017,0.018],[0.781,0.029,0.028],[8.694,0.874,0.859],[0.1,0.033,0.032],[0.347,0.088,0.086],[3.826,0.116,0.114],[3.991,0.856,0.692],[9.63,0.559,0.542],[9.58,0.544,0.551],[0.276,0.056,0.056],[0.106,0.051,0.054],[0.058,0.038,0.035],[0.092,0.026,0.028],[0.233,0.119,0.129],[0.051,0.022,0.022],[0.042,0.015,0.016],[0.033,0.015,0.014]],"source":"clickhouse-tencent/results/c6a.metal.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":310,"data_size":15244501016,"result":[[0.002,0.002,0.002],[0.071,0.015,0.018],[0.412,0.101,0.094],[1.056,0.134,0.166],[1.714,1.064,1.212],[2.317,1.324,1.356],[0.077,0.028,0.028],[0.042,0.022,0.027],[1.901,1.534,1.513],[1.989,1.805,1.735],[0.892,0.36,0.373],[1.015,0.451,0.441],[1.808,1.099,1.048],[2.929,1.815,1.664],[1.96,1.313,1.334],[0.993,0.88,0.867],[3.604,2.948,2.973],[2.266,1.204,1.186],[10.603,9.457,9.536],[0.209,0.003,0.003],[11.114,0.874,0.853],[12.686,0.2,0.2],[15.767,1.223,1.206],[1.875,0.126,0.082],[1.709,0.03,0.029],[1.529,0.429,0.422],[1.243,0.031,0.027],[0.956,0.314,0.318],[23.671,22.84,22.699],[0.154,0.11,0.098],[1.092,0.852,0.862],[4.175,1.192,1.121],[18.195,18.34,17.963],[21.912,18.926,19.221],[23.698,17.976,17.941],[1.018,0.675,0.647],[0.113,0.077,0.069],[0.062,0.044,0.048],[0.074,0.038,0.034],[0.217,0.151,0.159],[0.045,0.018,0.02],[0.03,0.014,0.017],[0.023,0.017,0.015]],"source":"clickhouse-tencent/results/c6a.xlarge.json"}
-,{"system":"ClickHouse (TCHouse-C)","date":"2025-09-10","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":5,"data_size":15252496294,"result":[[0.002,0.002,0.002],[0.021,0.014,0.011],[0.041,0.013,0.013],[0.077,0.018,0.013],[0.247,0.052,0.055],[1.091,0.066,0.067],[0.014,0.01,0.01],[0.022,0.017,0.016],[0.392,0.278,0.277],[0.616,0.285,0.288],[0.185,0.096,0.077],[0.211,0.1,0.101],[0.855,0.071,0.086],[1.802,0.115,0.131],[1.008,0.082,0.078],[0.321,0.057,0.055],[1.892,0.121,0.123],[1.604,0.047,0.048],[3.388,0.196,0.188],[0.055,0.003,0.002],[9.467,0.056,0.053],[10.95,0.035,0.033],[13.924,0.081,0.078],[1.557,0.054,0.054],[1.405,0.019,0.014],[1.135,0.028,0.028],[1.607,0.015,0.013],[0.661,0.025,0.035],[8.347,0.459,0.451],[0.066,0.045,0.042],[0.202,0.065,0.065],[3.676,0.076,0.075],[3.649,0.321,0.315],[9.321,0.294,0.29],[9.335,0.281,0.272],[0.081,0.049,0.043],[0.037,0.023,0.024],[0.028,0.019,0.019],[0.034,0.018,0.016],[0.069,0.135,0.141],[0.026,0.014,0.014],[0.023,0.013,0.012],[0.018,0.011,0.01]],"source":"clickhouse-tencent/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.124,0.015,0.014],[0.254,0.042,0.043],[0.338,0.055,0.056],[0.86,0.526,0.512],[1.194,0.752,0.754],[0.083,0.014,0.012],[0.065,0.017,0.018],[1.025,0.631,0.655],[1.13,0.708,0.713],[0.816,0.192,0.184],[0.909,0.228,0.224],[1.234,0.767,0.745],[2.089,1.161,1.167],[1.591,0.909,0.829],[0.891,0.474,0.473],[3.34,2.229,2.248],[1.996,1.271,1.248],[6.01,4.481,4.557],[0.929,0.007,0.007],[6.235,0.47,0.462],[6.524,0.115,0.111],[7.016,0.65,0.664],[15.964,0.649,0.616],[1.586,0.305,0.297],[0.774,0.235,0.236],[1.387,0.3,0.301],[6.133,0.954,0.886],[12.331,10,9.965],[0.206,0.044,0.041],[1.633,0.675,0.692],[3.231,0.9,0.918],[10.338,9.216,9.413],[8.898,3.852,3.848],[8.706,3.813,3.815],[0.583,0.377,0.363],[0.185,0.058,0.057],[0.11,0.033,0.033],[0.153,0.028,0.026],[0.277,0.102,0.107],[0.135,0.016,0.015],[0.105,0.015,0.015],[0.086,0.014,0.014]],"source":"clickhouse-web/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.002],[0.188,0.011,0.009],[0.289,0.025,0.025],[0.359,0.031,0.03],[0.516,0.331,0.332],[0.837,0.433,0.423],[0.085,0.01,0.009],[0.06,0.01,0.01],[0.749,0.471,0.433],[0.717,0.478,0.477],[0.504,0.136,0.136],[0.534,0.155,0.161],[0.827,0.549,0.563],[1.257,0.734,0.746],[1.029,0.52,0.568],[0.566,0.386,0.388],[2.19,1.561,1.711],[1.376,0.89,0.899],[3.991,2.934,2.887],[0.85,0.007,0.008],[4.536,0.38,0.382],[3.473,0.115,0.115],[5.47,0.666,0.672],[29.167,0.519,0.5],[1.038,0.168,0.171],[0.465,0.16,0.158],[0.98,0.161,0.166],[3.334,0.775,0.779],[6.287,5.103,5.097],[0.132,0.03,0.03],[1.095,0.413,0.414],[1.988,0.653,0.642],[4.342,3.717,3.664],[4.865,2.71,2.685],[4.892,2.697,2.713],[0.442,0.272,0.271],[0.184,0.041,0.04],[0.131,0.023,0.025],[0.168,0.021,0.022],[0.216,0.079,0.076],[0.148,0.012,0.012],[0.119,0.012,0.011],[0.118,0.012,0.012]],"source":"clickhouse-web/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse (web)","date":"2025-09-07","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.183,0.014,0.015],[0.625,0.018,0.018],[0.534,0.018,0.019],[0.324,0.176,0.177],[1.274,0.193,0.191],[0.149,0.016,0.014],[0.114,0.017,0.016],[0.737,0.291,0.298],[0.499,0.311,0.309],[0.737,0.107,0.11],[0.681,0.098,0.097],[0.466,0.169,0.171],[0.534,0.243,0.216],[0.589,0.175,0.186],[0.211,0.101,0.092],[0.585,0.345,0.372],[1.413,0.26,0.259],[1.081,0.625,0.71],[0.48,0.007,0.007],[2.12,0.098,0.117],[1.06,0.067,0.064],[2.235,0.228,0.224],[47.173,0.206,0.193],[0.467,0.061,0.061],[0.411,0.052,0.052],[0.435,0.062,0.058],[1.067,0.243,0.231],[2.032,0.774,0.751],[0.238,0.036,0.037],[0.711,0.154,0.154],[0.853,0.233,0.239],[2.035,0.958,0.908],[1.597,0.747,0.745],[1.591,0.78,0.779],[0.181,0.071,0.069],[0.207,0.033,0.039],[0.186,0.025,0.024],[0.241,0.024,0.025],[0.322,0.062,0.065],[0.4,0.018,0.016],[0.217,0.016,0.015],[0.095,0.016,0.015]],"source":"clickhouse-web/results/c6a.metal.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.147,0.02,0.021],[0.293,0.076,0.075],[0.562,0.099,0.097],[1.234,0.811,0.809],[2.188,1.358,1.346],[0.058,0.019,0.019],[0.06,0.025,0.023],[1.64,1.065,1.162],[1.819,1.212,1.215],[1.418,0.326,0.323],[1.891,0.382,0.392],[2.069,1.339,1.338],[3.49,2.046,1.981],[2.689,1.483,1.484],[1.268,0.947,0.827],[5.72,4.231,4.349],[5.77,2.464,2.368],[15.023,13.613,13.347],[0.824,0.007,0.007],[12.059,0.871,0.862],[12.656,0.204,0.196],[13.885,4.859,2.729],[25.009,6.801,6.384],[4.209,0.579,0.587],[1.133,0.473,0.473],[2.628,0.586,0.576],[12.275,1.757,1.815],[24.365,19.857,19.752],[0.23,0.069,0.067],[2.928,1.2,1.188],[6.263,1.494,1.539],[17.189,15.068,15.176],[24.764,15.87,14.992],[24.089,14.122,16.311],[1.046,0.6,0.59],[0.264,0.077,0.079],[0.162,0.04,0.038],[0.204,0.032,0.03],[0.397,0.137,0.142],[0.175,0.018,0.019],[0.131,0.018,0.02],[0.091,0.018,0.019]],"source":"clickhouse-web/results/c6a.xlarge.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.187,0.02,0.019],[0.322,0.021,0.021],[0.518,0.02,0.021],[0.493,0.332,0.326],[0.718,0.335,0.331],[0.053,0.022,0.019],[0.087,0.02,0.023],[0.785,0.293,0.276],[0.468,0.283,0.286],[0.697,0.123,0.119],[0.565,0.099,0.1],[0.383,0.099,0.097],[0.352,0.141,0.127],[0.34,0.086,0.084],[0.192,0.056,0.054],[0.355,0.142,0.141],[0.317,0.117,0.114],[0.787,0.269,0.265],[0.447,0.007,0.007],[1.181,0.05,0.05],[1.547,0.049,0.046],[1.817,0.114,0.109],[33.655,0.173,0.147],[0.274,0.042,0.044],[0.233,0.033,0.034],[1.186,0.047,0.044],[1.603,0.144,0.14],[1.482,0.455,0.437],[0.171,0.047,0.049],[0.502,0.097,0.099],[1.423,0.122,0.119],[1.523,0.324,0.306],[1.516,0.311,0.314],[1.62,0.306,0.3],[0.184,0.049,0.049],[0.142,0.029,0.028],[0.096,0.02,0.02],[0.15,0.018,0.019],[0.264,0.059,0.053],[0.168,0.016,0.016],[0.148,0.014,0.014],[0.129,0.013,0.014]],"source":"clickhouse-web/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-30","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.001,0.001,0.001],[0.127,0.01,0.009],[0.215,0.02,0.021],[0.261,0.027,0.029],[0.379,0.17,0.165],[0.598,0.278,0.275],[0.055,0.01,0.008],[0.063,0.01,0.009],[0.49,0.22,0.225],[0.544,0.249,0.253],[0.483,0.094,0.094],[0.54,0.123,0.117],[0.58,0.286,0.261],[0.948,0.369,0.369],[0.852,0.319,0.302],[0.392,0.156,0.156],[1.421,0.725,0.715],[0.934,0.402,0.408],[1.964,1.173,1.199],[0.466,0.007,0.007],[3.32,0.188,0.196],[3.44,0.049,0.048],[3.861,0.25,0.249],[12.66,0.292,0.287],[0.956,0.119,0.118],[0.411,0.097,0.099],[1.279,0.119,0.12],[3.301,0.347,0.342],[4.392,2.681,2.691],[0.171,0.027,0.026],[1.512,0.257,0.236],[1.851,0.301,0.309],[1.9,1.021,0.992],[4.042,1.187,1.15],[4.049,1.184,1.127],[0.301,0.115,0.112],[0.163,0.026,0.025],[0.09,0.016,0.016],[0.143,0.015,0.015],[0.206,0.041,0.041],[0.105,0.01,0.01],[0.101,0.01,0.01],[0.11,0.009,0.009]],"source":"clickhouse-web/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse (web)","date":"2025-08-30","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.001,0.001,0.001],[0.14,0.013,0.013],[0.184,0.014,0.013],[0.205,0.014,0.013],[0.328,0.296,0.223],[0.485,0.272,0.27],[0.061,0.016,0.014],[0.095,0.02,0.02],[0.394,0.194,0.195],[0.421,0.199,0.199],[0.412,0.084,0.086],[0.3,0.073,0.072],[0.263,0.081,0.081],[0.326,0.105,0.107],[0.278,0.08,0.079],[0.206,0.051,0.048],[0.382,0.15,0.147],[0.336,0.117,0.118],[0.566,0.298,0.254],[0.378,0.008,0.007],[1.684,0.061,0.057],[1.453,0.037,0.038],[1.811,0.103,0.099],[10.642,0.169,0.166],[0.336,0.038,0.037],[0.217,0.033,0.031],[0.267,0.04,0.041],[1.736,0.123,0.118],[1.297,0.382,0.38],[0.2,0.062,0.062],[0.339,0.075,0.075],[1.406,0.102,0.098],[1.562,0.344,0.285],[1.583,0.269,0.258],[1.6,0.266,0.27],[0.187,0.043,0.044],[0.146,0.032,0.032],[0.086,0.022,0.02],[0.143,0.021,0.019],[0.21,0.056,0.046],[0.132,0.016,0.015],[0.142,0.015,0.015],[0.122,0.013,0.013]],"source":"clickhouse-web/results/c8g.metal-48xl.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":275,"data_size":14465711160,"result":[[0.002,0.001,0.001],[0.04,0.009,0.008],[0.168,0.04,0.044],[0.898,0.061,0.058],[0.968,0.542,0.555],[1.238,0.774,0.799],[0.036,0.014,0.014],[0.035,0.012,0.012],[0.783,0.649,0.646],[0.898,0.733,0.745],[0.247,0.156,0.158],[0.505,0.183,0.18],[1.382,0.791,0.78],[1.869,1.213,1.161],[1.151,0.912,0.858],[0.735,0.489,0.493],[3.035,2.379,2.432],[2.065,1.341,1.347],[5.878,4.862,4.782],[0.198,0.004,0.004],[9.918,0.467,0.446],[10.743,0.105,0.103],[13.119,0.642,0.627],[6.812,1.262,1.268],[2.579,0.296,0.277],[0.973,0.233,0.232],[2.476,0.281,0.283],[9.524,0.937,0.913],[11.258,10.508,10.495],[0.071,0.045,0.046],[2.118,0.647,0.643],[4.763,0.834,0.782],[10.721,9.894,9.919],[10.852,4.182,4.17],[11.007,4.188,4.047],[0.391,0.343,0.35],[0.084,0.064,0.058],[0.039,0.026,0.028],[0.052,0.019,0.02],[0.134,0.096,0.101],[0.029,0.016,0.013],[0.029,0.011,0.011],[0.022,0.012,0.01]],"source":"clickhouse/results/c6a.2xlarge.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":221,"data_size":14470042218,"result":[[0.002,0.001,0.001],[0.018,0.006,0.006],[0.043,0.021,0.021],[0.578,0.029,0.028],[0.829,0.344,0.341],[0.714,0.455,0.446],[0.02,0.009,0.009],[0.021,0.008,0.008],[0.513,0.44,0.463],[0.619,0.507,0.492],[0.191,0.13,0.133],[0.377,0.141,0.15],[1.211,0.542,0.536],[1.554,0.8,0.789],[0.864,0.601,0.569],[0.456,0.38,0.387],[2.101,1.636,1.616],[1.668,0.937,0.923],[4.678,3.045,3.025],[0.216,0.004,0.004],[9.685,0.343,0.334],[10.469,0.107,0.107],[12.873,0.649,0.639],[6.166,0.982,1.034],[2.265,0.164,0.16],[1.067,0.147,0.149],[2.532,0.164,0.162],[9.447,0.689,0.694],[7.788,5.224,5.238],[0.058,0.027,0.027],[2.246,0.415,0.442],[4.658,0.616,0.603],[5.456,3.855,3.791],[10.698,2.856,2.841],[10.546,2.865,2.873],[0.304,0.262,0.26],[0.096,0.067,0.063],[0.041,0.036,0.029],[0.057,0.022,0.022],[0.154,0.114,0.118],[0.039,0.016,0.02],[0.039,0.012,0.012],[0.03,0.011,0.011]],"source":"clickhouse/results/c6a.4xlarge.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":426,"data_size":14427778058,"result":[[0.015,0.007,0.006],[0.208,0.043,0.046],[0.466,0.217,0.253],[0.862,0.381,0.287],[3.658,2.317,2.363],[5.301,3.619,3.333],[0.063,0.043,0.042],[0.068,0.033,0.032],[3.205,2.635,2.873],[3.576,3.115,3.121],[1.003,0.628,0.633],[1.391,0.784,0.762],[4.257,3.483,3.494],[9.796,9.338,9.427],[7.139,6.802,7.021],[2.938,1.884,1.878],[17.899,17.525,17.565],[13.063,12.741,12.829],[37.234,36.508,37.449],[0.452,0.011,0.015],[12.3,3.644,3.657],[13.008,0.725,0.735],[13.48,5.026,5.45],[7.707,3.398,4.188],[2.222,2.087,0.99],[1.261,0.824,1.001],[2.009,1.034,0.998],[8.504,4.776,4.324],[42.399,41.022,41.236],[0.195,0.109,0.11],[2.959,2.212,2.106],[4.795,3.371,4.53],[30.25,30.631,30.964],[29.403,29.711,29.427],[29.57,29.538,29.383],[1.316,1.045,1.04],[0.206,0.141,0.159],[0.069,0.055,0.054],[0.102,0.041,0.042],[0.364,0.261,0.253],[0.052,0.023,0.022],[0.043,0.018,0.018],[0.037,0.023,0.023]],"source":"clickhouse/results/c6a.large.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":7,"data_size":14467556065,"result":[[0.003,0.002,0.002],[0.02,0.011,0.01],[0.042,0.012,0.013],[0.092,0.014,0.015],[0.79,0.173,0.168],[0.91,0.167,0.168],[0.014,0.01,0.009],[0.016,0.012,0.011],[0.389,0.288,0.294],[0.593,0.295,0.301],[0.17,0.091,0.093],[0.173,0.097,0.094],[0.818,0.139,0.129],[1.573,0.185,0.182],[0.778,0.159,0.144],[0.158,0.085,0.086],[1.804,0.315,0.284],[1.203,0.229,0.208],[3.047,0.56,0.515],[0.121,0.006,0.006],[8.624,0.077,0.085],[10.011,0.05,0.046],[12.342,0.127,0.136],[6.2,0.556,0.559],[1.771,0.047,0.045],[0.876,0.04,0.034],[2.4,0.047,0.045],[9.066,0.191,0.176],[7.162,0.856,0.854],[0.048,0.03,0.032],[1.306,0.127,0.126],[4.653,0.162,0.182],[3.439,0.866,0.671],[8.771,0.641,0.61],[8.745,0.604,0.597],[0.09,0.064,0.064],[0.091,0.054,0.054],[0.04,0.031,0.037],[0.052,0.025,0.022],[0.153,0.099,0.108],[0.03,0.016,0.019],[0.03,0.013,0.014],[0.023,0.012,0.013]],"source":"clickhouse/results/c6a.metal.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":283,"data_size":15250223791,"result":[[0.003,0.002,0.002],[0.038,0.009,0.009],[0.285,0.042,0.04],[0.901,0.063,0.058],[1.203,0.521,0.536],[1.286,0.688,0.653],[0.03,0.015,0.014],[0.027,0.011,0.012],[0.836,0.643,0.642],[0.849,0.75,0.748],[0.243,0.156,0.158],[0.565,0.194,0.188],[1.411,0.546,0.536],[1.837,0.985,0.886],[1.124,0.685,0.681],[0.565,0.479,0.481],[2.233,1.584,1.563],[1.865,0.608,0.605],[4.444,2.682,2.647],[0.25,0.002,0.002],[10.608,0.472,0.424],[11.575,0.104,0.108],[14.438,0.63,0.638],[0.995,0.063,0.056],[1.585,0.019,0.018],[1.409,0.212,0.208],[1.351,0.019,0.02],[0.897,0.156,0.152],[11.258,10.775,10.72],[0.065,0.042,0.043],[1.035,0.457,0.469],[3.65,0.613,0.607],[10.8,9.998,9.979],[16.096,7.961,7.742],[15.451,6.792,7.247],[0.409,0.395,0.373],[0.094,0.044,0.043],[0.048,0.026,0.027],[0.057,0.019,0.02],[0.174,0.089,0.095],[0.04,0.013,0.014],[0.03,0.011,0.011],[0.026,0.011,0.013]],"source":"clickhouse-tencent/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":215,"data_size":15254417942,"result":[[0.002,0.001,0.001],[0.018,0.007,0.007],[0.048,0.023,0.022],[0.7,0.03,0.029],[0.944,0.41,0.406],[0.999,0.421,0.4],[0.017,0.01,0.009],[0.017,0.009,0.009],[0.674,0.483,0.478],[1.044,0.506,0.544],[0.213,0.135,0.134],[0.838,0.144,0.133],[1.585,0.439,0.443],[2.019,0.682,0.674],[1.154,0.482,0.518],[0.427,0.384,0.389],[2.206,1.245,1.244],[1.772,0.5,0.509],[4.442,2.153,2.152],[0.078,0.002,0.002],[10.893,0.317,0.311],[12.121,0.113,0.118],[14.921,0.699,0.693],[1.025,0.058,0.052],[1.684,0.016,0.015],[1.537,0.171,0.17],[1.495,0.017,0.017],[0.987,0.087,0.084],[9.514,5.323,5.354],[0.05,0.028,0.028],[1.281,0.303,0.32],[4.246,0.495,0.522],[5.783,3.913,3.836],[11.943,2.334,2.32],[11.793,2.333,2.254],[0.417,0.263,0.267],[0.05,0.037,0.037],[0.038,0.022,0.022],[0.038,0.018,0.016],[0.107,0.089,0.086],[0.029,0.016,0.013],[0.025,0.01,0.01],[0.022,0.009,0.009]],"source":"clickhouse-tencent/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":417,"data_size":15220638021,"result":[[0.007,0.002,0.004],[0.122,0.041,0.036],[0.447,0.18,0.175],[0.778,0.418,0.341],[4.234,3.099,3.236],[4.905,4.03,3.758],[0.098,0.099,0.077],[0.075,0.056,0.052],[4.889,3.915,4.12],[4.878,3.421,3.207],[0.993,0.666,0.669],[1.091,0.793,0.783],[3.233,2.3,2.187],[8.568,8.492,8.489],[3.76,3.158,2.968],[2.504,1.965,1.848],[12.592,12.467,12.37],[3.109,2.713,2.658],[21.279,21.745,21.356],[0.445,0.004,0.003],[10.854,3.377,3.249],[11.731,1.092,0.974],[17.103,7.681,6.972],[1.848,0.247,0.221],[1.137,0.061,0.051],[1.374,1.002,0.935],[1.12,0.058,0.054],[1.065,0.769,0.709],[56.669,59.097,43.521],[0.191,0.111,0.11],[1.787,1.421,1.7],[3.676,2.224,2.694],[29.367,29.87,29.66],[24.621,24.249,24.623],[24.374,24.474,24.006],[1.277,1.058,1.055],[0.179,0.13,0.113],[0.082,0.059,0.058],[0.115,0.042,0.043],[0.361,0.228,0.227],[0.051,0.022,0.022],[0.045,0.019,0.018],[0.036,0.024,0.023]],"source":"clickhouse-tencent/results/c6a.large.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":7,"data_size":15255139626,"result":[[0.003,0.002,0.002],[0.026,0.012,0.01],[0.037,0.013,0.013],[0.257,0.014,0.015],[0.732,0.091,0.095],[1.327,0.113,0.115],[0.017,0.01,0.01],[0.02,0.013,0.013],[0.904,0.295,0.298],[1.072,0.31,0.315],[0.345,0.094,0.096],[0.705,0.11,0.103],[1.292,0.12,0.122],[2.043,0.175,0.164],[1.245,0.135,0.129],[0.243,0.086,0.084],[1.867,0.223,0.229],[1.353,0.077,0.074],[3.462,0.378,0.377],[0.053,0.003,0.002],[9.406,0.075,0.085],[10.785,0.036,0.035],[13.902,0.128,0.118],[1.062,0.054,0.048],[1.291,0.019,0.018],[1.135,0.041,0.037],[1.408,0.015,0.015],[0.643,0.027,0.027],[8.437,0.847,0.884],[0.052,0.033,0.034],[0.191,0.077,0.083],[3.619,0.127,0.118],[3.677,0.899,0.755],[9.537,0.558,0.58],[9.436,0.576,0.566],[0.089,0.058,0.06],[0.085,0.062,0.049],[0.046,0.029,0.035],[0.051,0.023,0.024],[0.14,0.105,0.109],[0.033,0.018,0.02],[0.03,0.014,0.012],[0.025,0.013,0.012]],"source":"clickhouse-tencent/results/c6a.metal.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":321,"data_size":15244103880,"result":[[0.003,0.002,0.002],[0.074,0.025,0.027],[0.294,0.097,0.103],[1.116,0.169,0.153],[1.698,1.202,1.475],[1.965,1.353,1.353],[0.039,0.032,0.075],[0.043,0.023,0.021],[1.902,1.454,1.301],[1.609,1.452,1.411],[0.448,0.299,0.297],[0.484,0.378,0.357],[1.362,1.022,0.995],[2.352,1.797,1.649],[1.784,1.384,1.456],[1.007,0.859,0.896],[3.537,2.998,2.879],[2.09,1.196,1.219],[10.173,9.239,9.144],[0.209,0.002,0.003],[10.56,0.872,0.859],[12.058,0.202,0.187],[15.042,1.197,1.207],[1.291,0.088,0.081],[1.59,0.028,0.026],[1.455,0.426,0.418],[1.093,0.029,0.025],[0.926,0.314,0.316],[23.659,22.583,22.503],[0.109,0.071,0.073],[0.977,0.84,0.85],[4.035,1.154,1.14],[18.047,17.871,17.928],[21.289,18.124,17.897],[21.123,17.473,18.127],[0.921,0.662,0.647],[0.111,0.076,0.072],[0.063,0.045,0.043],[0.071,0.036,0.034],[0.207,0.146,0.149],[0.036,0.018,0.019],[0.033,0.016,0.016],[0.026,0.023,0.02]],"source":"clickhouse-tencent/results/c6a.xlarge.json"}
+,{"system":"ClickHouse (TCHouse-C)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":5,"data_size":15251226785,"result":[[0.002,0.002,0.002],[0.022,0.012,0.011],[0.041,0.013,0.08],[0.44,0.012,0.011],[0.729,0.062,0.052],[1.374,0.064,0.063],[0.017,0.01,0.01],[0.022,0.014,0.015],[1.045,0.274,0.276],[1.257,0.283,0.279],[0.47,0.098,0.096],[0.761,0.105,0.105],[1.331,0.071,0.071],[2.06,0.113,0.11],[1.426,0.083,0.078],[0.664,0.061,0.058],[2.178,0.13,0.119],[2.011,0.048,0.05],[3.676,0.19,0.186],[0.162,0.002,0.003],[10.205,0.06,0.105],[11.35,0.034,0.032],[14.477,0.082,0.078],[2.35,0.064,0.061],[1.836,0.014,0.015],[1.369,0.027,0.025],[1.834,0.014,0.015],[0.841,0.026,0.023],[8.546,0.536,0.514],[0.072,0.042,0.041],[0.216,0.078,0.064],[3.647,0.093,0.071],[3.633,0.34,0.329],[9.385,0.281,0.28],[9.461,0.29,0.286],[0.108,0.048,0.054],[0.087,0.044,0.046],[0.042,0.027,0.027],[0.054,0.022,0.023],[0.153,0.119,0.114],[0.069,0.019,0.022],[0.032,0.016,0.015],[0.026,0.013,0.014]],"source":"clickhouse-tencent/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.002],[0.117,0.014,0.014],[0.257,0.045,0.043],[0.36,0.053,0.053],[0.8,0.508,0.491],[1.358,0.748,0.743],[0.069,0.013,0.014],[0.069,0.017,0.016],[1.276,0.638,0.644],[1.11,0.72,0.706],[0.908,0.194,0.19],[0.908,0.229,0.216],[1.419,0.763,0.742],[2.008,1.168,1.108],[1.615,0.832,0.805],[0.921,0.474,0.462],[3.357,2.311,2.35],[1.986,1.323,1.291],[5.756,4.671,4.626],[0.916,0.003,0.003],[6.342,0.409,0.391],[6.649,0.116,0.112],[7.281,0.666,0.667],[16.283,0.586,0.567],[1.765,0.301,0.293],[1.134,0.237,0.241],[1.424,0.298,0.29],[5.759,0.685,0.691],[12.531,10.129,10.084],[0.194,0.041,0.041],[1.274,0.571,0.606],[2.214,0.709,0.706],[10.744,9.722,9.782],[9.004,4.041,3.804],[8.824,3.889,3.964],[0.574,0.351,0.349],[0.191,0.063,0.057],[0.138,0.032,0.032],[0.169,0.028,0.027],[0.259,0.106,0.106],[0.125,0.017,0.017],[0.1,0.016,0.016],[0.162,0.014,0.015]],"source":"clickhouse-web/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.218,0.01,0.01],[0.395,0.028,0.031],[0.639,0.032,0.032],[0.557,0.34,0.337],[1.088,0.432,0.446],[0.104,0.009,0.009],[0.082,0.01,0.011],[1.102,0.463,0.463],[0.749,0.477,0.512],[0.51,0.134,0.137],[0.637,0.159,0.167],[0.813,0.535,0.531],[1.215,0.737,0.746],[1.064,0.531,0.531],[0.562,0.391,0.387],[2.144,1.606,1.598],[1.424,0.931,0.928],[4.095,2.952,2.943],[0.7,0.003,0.003],[3.409,0.356,0.362],[3.538,0.113,0.116],[3.961,0.684,0.667],[25.51,0.485,0.484],[0.966,0.162,0.167],[0.466,0.156,0.156],[0.986,0.166,0.161],[3.105,0.375,0.37],[6.347,5.136,5.143],[0.14,0.031,0.033],[0.834,0.356,0.351],[1.486,0.573,0.564],[4.344,3.759,3.615],[4.94,2.644,2.696],[4.977,2.693,2.711],[0.442,0.258,0.275],[0.16,0.043,0.046],[0.13,0.024,0.025],[0.142,0.023,0.021],[0.208,0.084,0.079],[0.142,0.015,0.014],[0.12,0.013,0.012],[0.094,0.013,0.012]],"source":"clickhouse-web/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.15,0.014,0.013],[0.2,0.018,0.016],[0.188,0.017,0.017],[0.328,0.179,0.175],[0.548,0.194,0.18],[0.057,0.016,0.014],[0.074,0.015,0.017],[0.489,0.3,0.29],[0.516,0.327,0.313],[0.307,0.112,0.111],[0.324,0.097,0.101],[0.481,0.174,0.168],[0.571,0.224,0.239],[0.49,0.172,0.172],[0.214,0.097,0.09],[1.375,0.323,0.37],[0.503,0.293,0.258],[1.052,0.637,0.683],[0.482,0.003,0.004],[1.999,0.099,0.118],[1.725,0.069,0.064],[1.743,0.226,0.223],[30.111,0.2,0.168],[0.431,0.059,0.059],[0.41,0.052,0.046],[0.422,0.058,0.06],[1.197,0.113,0.116],[1.327,0.752,0.783],[0.144,0.036,0.037],[1.201,0.115,0.107],[1.326,0.204,0.175],[1.151,0.906,0.832],[1.511,0.718,0.705],[1.51,0.744,0.664],[0.178,0.065,0.066],[0.144,0.041,0.034],[0.106,0.024,0.023],[0.147,0.026,0.021],[0.259,0.066,0.076],[0.113,0.016,0.018],[0.11,0.016,0.016],[0.105,0.016,0.016]],"source":"clickhouse-web/results/c6a.metal.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.002,0.001],[0.117,0.021,0.021],[0.283,0.078,0.077],[0.536,0.101,0.101],[1.226,0.801,0.824],[2.048,1.402,1.371],[0.069,0.02,0.019],[0.053,0.024,0.023],[1.705,1.105,1.178],[1.871,1.25,1.262],[1.425,0.328,0.32],[1.529,0.38,0.381],[2.091,1.337,1.31],[3.402,1.988,1.983],[2.678,1.453,1.44],[1.555,0.915,0.872],[7.505,4.361,4.073],[5.653,2.357,2.204],[14.613,13.508,13.674],[0.889,0.003,0.003],[11.998,0.751,0.707],[12.844,0.203,0.19],[14.077,5.664,3.079],[26.249,7.07,6.43],[2.537,0.57,0.575],[1.088,0.437,0.435],[2.476,0.583,0.563],[11.419,1.327,1.337],[24.912,20.275,19.989],[0.291,0.068,0.069],[2.215,1.017,1.022],[4.393,1.275,1.318],[16.97,15.603,15.596],[24.318,14.577,15.002],[23.725,15.786,15.865],[1.088,0.613,0.594],[0.22,0.082,0.081],[0.114,0.05,0.04],[0.207,0.032,0.032],[0.336,0.159,0.134],[0.15,0.02,0.02],[0.13,0.019,0.019],[0.171,0.019,0.019]],"source":"clickhouse-web/results/c6a.xlarge.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.179,0.019,0.02],[0.218,0.022,0.022],[0.255,0.021,0.021],[0.474,0.342,0.338],[0.559,0.357,0.332],[0.059,0.024,0.02],[0.11,0.023,0.023],[0.519,0.299,0.294],[0.517,0.292,0.302],[0.561,0.126,0.126],[0.372,0.099,0.099],[0.311,0.103,0.098],[0.388,0.134,0.141],[0.314,0.09,0.089],[0.189,0.056,0.057],[0.412,0.17,0.152],[0.355,0.118,0.124],[0.66,0.278,0.27],[0.441,0.003,0.003],[1.638,0.048,0.05],[1.756,0.045,0.044],[1.942,0.129,0.113],[12.132,0.17,0.138],[0.342,0.041,0.04],[0.215,0.034,0.037],[0.289,0.044,0.041],[1.473,0.078,0.077],[1.315,0.465,0.466],[0.2,0.052,0.051],[0.279,0.092,0.096],[1.357,0.104,0.097],[1.577,0.322,0.326],[1.627,0.331,0.324],[1.593,0.327,0.324],[0.207,0.05,0.05],[0.155,0.029,0.03],[0.065,0.021,0.021],[0.153,0.02,0.02],[0.237,0.052,0.055],[0.114,0.018,0.016],[0.122,0.017,0.016],[0.115,0.016,0.016]],"source":"clickhouse-web/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.002,0.001,0.001],[0.127,0.011,0.01],[0.214,0.021,0.021],[1.181,0.028,0.028],[1.213,0.173,0.169],[0.664,0.306,0.309],[0.052,0.009,0.008],[0.038,0.01,0.01],[1.26,0.245,0.247],[1.226,0.28,0.275],[0.503,0.106,0.106],[0.538,0.132,0.132],[1.213,0.281,0.291],[1.246,0.409,0.398],[0.834,0.319,0.312],[0.35,0.16,0.159],[1.417,0.696,0.696],[0.955,0.445,0.441],[2.082,1.277,1.258],[0.486,0.003,0.003],[3.291,0.201,0.212],[3.401,0.054,0.054],[3.7,0.28,0.285],[12.481,0.317,0.309],[1.178,0.125,0.125],[1.131,0.103,0.103],[1.131,0.128,0.125],[3.05,0.269,0.268],[4.353,2.767,2.774],[0.224,0.028,0.028],[0.772,0.21,0.204],[1.22,0.283,0.258],[1.868,1.088,1.091],[3.956,1.228,1.225],[4.172,1.231,1.232],[0.314,0.15,0.146],[0.147,0.029,0.029],[0.107,0.018,0.018],[0.143,0.017,0.017],[0.218,0.045,0.046],[0.119,0.012,0.012],[0.108,0.011,0.011],[0.117,0.01,0.01]],"source":"clickhouse-web/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse (web)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative","serverless","stateless"],"load_time":0,"data_size":14557009492,"result":[[0.001,0.001,0.001],[0.177,0.013,0.012],[0.187,0.014,0.014],[0.224,0.013,0.014],[0.327,0.205,0.31],[0.516,0.246,0.287],[0.048,0.016,0.014],[0.086,0.017,0.017],[0.436,0.205,0.203],[0.412,0.213,0.212],[0.29,0.085,0.086],[0.283,0.074,0.074],[0.249,0.08,0.079],[0.326,0.104,0.101],[0.298,0.075,0.077],[0.187,0.048,0.049],[0.373,0.146,0.146],[1.195,0.114,0.114],[0.563,0.262,0.255],[0.426,0.002,0.002],[1.508,0.062,0.054],[1.505,0.039,0.038],[1.799,0.099,0.098],[23.493,0.173,0.168],[0.304,0.037,0.038],[0.193,0.032,0.033],[1.215,0.039,0.039],[1.313,0.066,0.066],[1.451,0.385,0.39],[0.203,0.065,0.064],[0.426,0.067,0.065],[0.662,0.08,0.077],[0.706,0.263,0.26],[1.793,0.258,0.258],[1.539,0.259,0.255],[0.175,0.044,0.042],[0.136,0.03,0.032],[0.123,0.021,0.022],[0.156,0.021,0.021],[0.253,0.049,0.048],[0.207,0.015,0.015],[0.132,0.015,0.015],[0.101,0.014,0.014]],"source":"clickhouse-web/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":275,"data_size":14463145748,"result":[[0.002,0.002,0.002],[0.028,0.009,0.008],[0.125,0.04,0.04],[0.616,0.056,0.055],[0.918,0.582,0.526],[1.251,0.78,0.772],[0.025,0.014,0.013],[0.025,0.011,0.011],[0.732,0.648,0.649],[0.898,0.745,0.776],[0.247,0.156,0.155],[0.525,0.182,0.187],[1.39,0.775,0.773],[1.952,1.156,1.157],[1.265,0.834,0.838],[0.709,0.488,0.497],[2.925,2.355,2.363],[2.094,1.307,1.311],[5.837,4.789,4.757],[0.201,0.002,0.003],[9.911,0.396,0.374],[10.829,0.1,0.102],[13.186,0.635,0.621],[6.67,0.559,0.545],[2.166,0.286,0.274],[0.819,0.23,0.226],[2.458,0.274,0.27],[9.568,0.698,0.686],[11.264,10.634,10.586],[0.067,0.043,0.041],[2.167,0.579,0.569],[4.807,0.716,0.688],[10.776,10.087,9.87],[11.257,3.991,3.948],[11.029,3.979,3.99],[0.389,0.346,0.362],[0.107,0.059,0.059],[0.049,0.029,0.028],[0.059,0.024,0.024],[0.181,0.1,0.115],[0.032,0.015,0.014],[0.027,0.011,0.011],[0.023,0.01,0.01]],"source":"clickhouse/results/c6a.2xlarge.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":220,"data_size":14462139925,"result":[[0.002,0.002,0.002],[0.017,0.007,0.006],[0.045,0.022,0.021],[0.431,0.035,0.03],[0.83,0.345,0.346],[0.636,0.426,0.428],[0.016,0.009,0.01],[0.015,0.009,0.009],[0.507,0.445,0.5],[0.68,0.506,0.508],[0.187,0.124,0.126],[0.461,0.148,0.145],[1.262,0.543,0.548],[1.593,0.821,0.797],[0.886,0.58,0.608],[0.464,0.391,0.388],[2.107,1.666,1.647],[1.616,0.941,0.954],[4.75,3.138,3.099],[0.173,0.002,0.003],[9.69,0.333,0.317],[10.512,0.112,0.108],[12.877,0.689,0.69],[6.193,0.453,0.45],[2.041,0.156,0.156],[0.93,0.14,0.141],[2.474,0.157,0.153],[9.422,0.377,0.366],[7.977,5.337,5.266],[0.051,0.029,0.027],[2.124,0.367,0.372],[4.73,0.542,0.603],[5.465,3.963,3.96],[10.771,2.959,2.966],[10.628,2.96,2.919],[0.307,0.283,0.277],[0.056,0.046,0.046],[0.038,0.021,0.021],[0.036,0.018,0.017],[0.103,0.085,0.083],[0.03,0.012,0.012],[0.024,0.009,0.009],[0.02,0.008,0.009]],"source":"clickhouse/results/c6a.4xlarge.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":410,"data_size":14430433955,"result":[[0.008,0.008,0.003],[0.177,0.05,0.034],[0.534,0.236,0.203],[0.786,0.359,0.306],[3.849,3.457,3.101],[5.609,5.009,5.166],[0.092,0.079,0.056],[0.131,0.069,0.045],[5.134,4.057,4.234],[5.696,3.635,3.293],[0.967,0.617,0.694],[1.042,0.753,0.75],[4.347,3.492,3.38],[9.399,8.841,9.434],[7.281,6.927,7.012],[2.971,1.747,1.741],[16.99,17.038,16.948],[12.636,11.791,12.76],[34.829,33.806,33.724],[0.418,0.003,0.003],[11.583,3.11,2.968],[13.232,0.904,1.011],[13.426,5.426,5.37],[6.793,2.226,2.2],[2.629,1.268,1.245],[1.411,1.035,1.24],[1.912,0.98,0.993],[8.512,3.834,3.492],[42.807,41.532,42.304],[0.231,0.109,0.109],[2.412,1.992,1.759],[4.792,3.403,3.584],[29.243,28.747,29.02],[26.688,26.654,26.561],[26.792,26.667,27.232],[1.455,0.988,0.981],[0.189,0.133,0.135],[0.072,0.056,0.057],[0.106,0.049,0.045],[0.384,0.245,0.274],[0.054,0.022,0.022],[0.044,0.019,0.019],[0.035,0.018,0.023]],"source":"clickhouse/results/c6a.large.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":7,"data_size":14464530126,"result":[[0.004,0.002,0.002],[0.021,0.011,0.01],[0.039,0.014,0.013],[0.086,0.014,0.014],[0.369,0.175,0.171],[0.805,0.179,0.165],[0.017,0.011,0.01],[0.018,0.012,0.013],[0.369,0.301,0.291],[0.636,0.313,0.311],[0.172,0.104,0.089],[0.151,0.092,0.077],[0.965,0.16,0.147],[1.581,0.216,0.205],[0.788,0.153,0.156],[0.189,0.089,0.085],[1.918,0.343,0.335],[1.238,0.235,0.23],[3.243,0.589,0.597],[0.062,0.003,0.003],[8.793,0.074,0.078],[10.239,0.049,0.045],[12.631,0.122,0.121],[6.63,0.167,0.17],[1.933,0.043,0.044],[0.937,0.043,0.039],[2.444,0.052,0.042],[9.192,0.106,0.108],[7.488,0.979,0.914],[0.048,0.034,0.033],[1.368,0.101,0.103],[4.792,0.144,0.127],[3.628,0.864,0.729],[8.935,0.668,0.644],[8.975,0.659,0.657],[0.092,0.068,0.06],[0.05,0.032,0.034],[0.03,0.028,0.021],[0.031,0.017,0.018],[0.075,0.054,0.052],[0.025,0.017,0.018],[0.021,0.013,0.011],[0.019,0.01,0.011]],"source":"clickhouse/results/c6a.metal.json"}
,{"system":"ClickHouse (tuned, memory)","date":"2025-06-20","machine":"c6a.metal","cluster_size":1,"comment":"","proprietary":"no","tuned":"yes","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":284.697,"data_size":82800083772,"result":[[0.010,0.009,0.010],[0.012,0.012,0.012],[0.015,0.017,0.018],[0.045,0.019,0.019],[0.148,0.110,0.103],[0.132,0.128,0.124],[0.032,0.013,0.014],[0.013,0.014,0.016],[0.173,0.169,0.163],[0.260,0.272,0.259],[0.342,0.044,0.046],[0.054,0.047,0.052],[0.145,0.150,0.134],[0.188,0.193,0.179],[0.149,0.153,0.143],[0.092,0.085,0.087],[0.289,0.268,0.272],[0.132,0.086,0.091],[0.584,0.523,0.522],[0.016,0.016,0.017],[0.205,0.147,0.148],[0.165,0.164,0.150],[0.262,0.166,0.162],[0.215,0.208,0.204],[0.052,0.050,0.047],[0.044,0.040,0.042],[0.048,0.046,0.046],[0.223,0.208,0.206],[0.321,0.275,0.292],[0.677,0.028,0.028],[0.087,0.087,0.083],[0.140,0.140,0.128],[0.980,0.836,0.816],[0.582,0.551,0.548],[0.580,0.550,0.579],[0.058,0.055,0.055],[0.037,0.035,0.036],[0.035,0.035,0.034],[0.039,0.048,0.033],[0.060,0.057,0.054],[0.027,0.027,0.029],[0.027,0.027,0.029],[0.024,0.025,0.026]],"source":"clickhouse/results/c6a.metal.tuned.memory.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":310,"data_size":14441474487,"result":[[0.002,0.003,0.002],[0.071,0.014,0.02],[0.204,0.089,0.087],[1.073,0.13,0.128],[1.523,1.136,1.179],[2.355,1.733,1.716],[0.054,0.025,0.025],[0.055,0.026,0.021],[1.861,1.433,1.4],[2.119,1.708,1.832],[0.696,0.326,0.337],[1.092,0.374,0.344],[1.914,1.484,1.498],[2.776,2.33,2.301],[2.092,1.623,1.62],[1.158,0.878,0.888],[5.383,7.304,7.322],[3.266,5.266,5.321],[16.934,15.594,15.957],[0.235,0.007,0.006],[10.347,0.919,0.912],[11.44,0.194,0.19],[13.757,1.16,1.178],[7.275,1.779,1.775],[2.682,0.557,0.557],[0.798,0.48,0.459],[2.325,0.59,0.562],[9.702,2.003,1.867],[25.301,22.542,22.46],[0.123,0.069,0.074],[1.765,1.226,1.21],[5.291,1.543,1.502],[19.027,17.658,18.594],[20.047,17.334,18.749],[16.336,13.707,14.309],[0.85,0.581,0.586],[0.119,0.077,0.083],[0.047,0.037,0.037],[0.066,0.027,0.028],[0.214,0.15,0.154],[0.034,0.017,0.016],[0.03,0.013,0.013],[0.024,0.014,0.014]],"source":"clickhouse/results/c6a.xlarge.json"}
-,{"system":"ClickHouse","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":5,"data_size":14462768490,"result":[[0.002,0.001,0.002],[0.024,0.012,0.01],[0.045,0.013,0.012],[0.156,0.012,0.011],[0.906,0.315,0.324],[0.972,0.327,0.322],[0.014,0.01,0.01],[0.019,0.014,0.014],[0.473,0.266,0.27],[0.984,0.281,0.283],[0.257,0.089,0.091],[0.675,0.1,0.099],[1.137,0.089,0.088],[1.95,0.123,0.122],[1.22,0.097,0.082],[0.543,0.052,0.054],[2.008,0.135,0.135],[1.787,0.109,0.107],[3.46,0.263,0.246],[0.07,0.005,0.005],[9.238,0.061,0.058],[10.517,0.043,0.041],[12.755,0.093,0.084],[6.777,0.61,0.594],[1.825,0.036,0.032],[1.171,0.029,0.026],[2.634,0.033,0.033],[9.423,0.114,0.102],[7.752,0.47,0.466],[0.096,0.038,0.04],[1.437,0.104,0.083],[5.006,0.106,0.104],[3.859,0.311,0.303],[8.991,0.314,0.3],[9.027,0.312,0.308],[0.117,0.045,0.044],[0.101,0.026,0.024],[0.042,0.025,0.021],[0.069,0.016,0.015],[0.203,0.129,0.118],[0.038,0.015,0.015],[0.035,0.013,0.012],[0.025,0.01,0.012]],"source":"clickhouse/results/c7a.metal-48xl.json"}
-,{"system":"ClickHouse","date":"2025-08-31","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":224,"data_size":14465212977,"result":[[0.001,0.001,0.001],[0.023,0.005,0.005],[0.098,0.015,0.017],[0.738,0.025,0.025],[0.77,0.161,0.153],[1.011,0.262,0.261],[0.018,0.008,0.008],[0.017,0.007,0.007],[0.521,0.252,0.219],[0.993,0.294,0.281],[0.34,0.09,0.093],[0.676,0.1,0.101],[1.186,0.244,0.254],[1.767,0.361,0.355],[0.941,0.288,0.281],[0.368,0.15,0.152],[2.133,0.657,0.651],[1.433,0.405,0.41],[3.568,1.216,1.203],[0.062,0.003,0.003],[9.412,0.198,0.188],[10.76,0.059,0.056],[12.97,0.255,0.261],[6.962,0.881,0.879],[2.38,0.106,0.106],[1.171,0.084,0.086],[2.617,0.106,0.108],[9.477,0.353,0.369],[7.885,2.8,2.784],[0.043,0.024,0.024],[2.191,0.24,0.229],[4.932,0.28,0.262],[4.099,1.072,1.062],[9.573,1.25,1.21],[9.696,1.252,1.221],[0.231,0.117,0.129],[0.04,0.024,0.024],[0.031,0.017,0.017],[0.036,0.013,0.013],[0.066,0.038,0.038],[0.027,0.01,0.01],[0.023,0.008,0.008],[0.019,0.007,0.007]],"source":"clickhouse/results/c8g.4xlarge.json"}
-,{"system":"ClickHouse","date":"2025-08-30","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":5,"data_size":14460771204,"result":[[0.002,0.001,0.001],[0.018,0.01,0.009],[0.042,0.01,0.01],[0.549,0.011,0.011],[0.964,0.267,0.255],[1.19,0.259,0.257],[0.012,0.01,0.009],[0.018,0.013,0.014],[0.769,0.196,0.188],[1.211,0.207,0.203],[0.567,0.072,0.071],[0.79,0.076,0.079],[1.22,0.075,0.072],[2.066,0.105,0.096],[1.306,0.075,0.071],[0.63,0.045,0.042],[2.114,0.141,0.141],[1.915,0.119,0.109],[3.581,0.242,0.235],[0.094,0.005,0.005],[9.666,0.074,0.075],[10.704,0.032,0.033],[12.991,0.097,0.093],[7.003,0.608,0.621],[2.276,0.033,0.034],[1.239,0.025,0.024],[2.689,0.033,0.033],[9.505,0.122,0.114],[7.925,0.457,0.461],[0.081,0.057,0.056],[1.83,0.066,0.065],[5.094,0.084,0.08],[3.489,0.272,0.266],[8.68,0.298,0.29],[8.692,0.301,0.288],[0.087,0.034,0.036],[0.04,0.025,0.024],[0.027,0.018,0.021],[0.034,0.017,0.017],[0.066,0.038,0.042],[0.024,0.013,0.013],[0.021,0.011,0.012],[0.019,0.011,0.01]],"source":"clickhouse/results/c8g.metal-48xl.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":322,"data_size":14440704594,"result":[[0.002,0.002,0.002],[0.044,0.015,0.016],[0.29,0.087,0.091],[1.08,0.13,0.131],[1.466,1.128,1.101],[2.317,1.819,1.884],[0.044,0.027,0.03],[0.05,0.021,0.022],[1.756,1.437,1.473],[2.099,1.676,1.734],[1.103,0.288,0.303],[0.819,0.353,0.349],[1.875,1.49,1.447],[2.568,2.229,2.17],[1.837,1.566,1.728],[1.153,0.877,0.875],[7.631,7.234,7.312],[5.709,5.309,5.169],[14.909,14.722,15.133],[0.204,0.003,0.003],[10.232,0.746,0.729],[11.481,0.185,0.186],[13.76,1.177,1.153],[7.241,1.011,0.992],[2.71,0.57,0.555],[0.802,0.461,0.46],[2.368,0.564,0.572],[9.449,1.417,1.485],[24.501,22.652,23.138],[0.111,0.073,0.073],[1.816,1.058,1.078],[5.306,1.36,1.323],[18.891,17.634,18.129],[19.264,18.928,17.726],[16.022,13.52,13.845],[0.834,0.574,0.604],[0.109,0.093,0.092],[0.05,0.036,0.034],[0.059,0.027,0.025],[0.192,0.137,0.13],[0.039,0.015,0.016],[0.034,0.016,0.013],[0.025,0.014,0.013]],"source":"clickhouse/results/c6a.xlarge.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":5,"data_size":14463377533,"result":[[0.002,0.002,0.001],[0.021,0.011,0.011],[0.034,0.013,0.013],[0.316,0.012,0.012],[1.028,0.325,0.334],[1.192,0.343,0.335],[0.016,0.011,0.012],[0.02,0.015,0.015],[0.718,0.279,0.279],[1.228,0.288,0.293],[0.457,0.117,0.119],[0.733,0.093,0.092],[1.188,0.092,0.087],[2.053,0.136,0.13],[1.265,0.084,0.082],[0.641,0.057,0.056],[2.056,0.154,0.143],[1.919,0.117,0.115],[3.635,0.267,0.257],[0.053,0.003,0.002],[9.533,0.062,0.057],[10.626,0.043,0.041],[13.057,0.099,0.084],[7.249,0.137,0.126],[2.588,0.031,0.035],[1.134,0.027,0.024],[2.664,0.031,0.034],[9.453,0.083,0.077],[7.882,0.485,0.487],[0.057,0.041,0.041],[1.819,0.069,0.069],[5.13,0.084,0.095],[3.99,0.317,0.313],[9.32,0.372,0.338],[9.27,0.351,0.336],[0.077,0.047,0.054],[0.069,0.046,0.046],[0.037,0.027,0.033],[0.044,0.024,0.022],[0.125,0.103,0.108],[0.031,0.022,0.018],[0.028,0.018,0.016],[0.023,0.013,0.012]],"source":"clickhouse/results/c7a.metal-48xl.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":220,"data_size":14465849263,"result":[[0.003,0.001,0.001],[0.086,0.006,0.005],[0.068,0.015,0.017],[0.654,0.025,0.026],[0.709,0.158,0.156],[1.108,0.27,0.272],[0.013,0.008,0.008],[0.014,0.007,0.008],[0.538,0.224,0.23],[1.019,0.265,0.269],[0.381,0.093,0.097],[0.72,0.101,0.103],[1.211,0.251,0.236],[1.823,0.362,0.371],[0.972,0.266,0.272],[0.401,0.15,0.148],[2.162,0.674,0.663],[1.38,0.417,0.416],[3.531,1.214,1.198],[0.079,0.002,0.002],[9.502,0.205,0.192],[10.765,0.06,0.062],[12.972,0.253,0.251],[6.707,0.297,0.302],[2.371,0.106,0.106],[1.208,0.087,0.086],[2.629,0.106,0.106],[9.559,0.264,0.262],[8.099,2.872,2.828],[0.052,0.025,0.025],[2.21,0.197,0.196],[5.009,0.235,0.23],[4.176,1.108,1.082],[9.577,1.213,1.19],[9.586,1.22,1.176],[0.199,0.132,0.133],[0.077,0.052,0.052],[0.038,0.03,0.029],[0.046,0.024,0.024],[0.143,0.085,0.085],[0.038,0.015,0.015],[0.036,0.012,0.012],[0.026,0.011,0.011]],"source":"clickhouse/results/c8g.4xlarge.json"}
+,{"system":"ClickHouse","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","ClickHouse derivative"],"load_time":6,"data_size":14453239588,"result":[[0.003,0.002,0.001],[0.022,0.012,0.011],[0.06,0.012,0.012],[0.205,0.012,0.011],[0.947,0.249,0.255],[1.077,0.27,0.271],[0.016,0.01,0.009],[0.022,0.016,0.016],[0.599,0.199,0.203],[1.102,0.209,0.209],[0.5,0.079,0.083],[0.693,0.066,0.07],[1.224,0.074,0.073],[2.025,0.1,0.099],[1.289,0.072,0.07],[0.589,0.046,0.043],[2.101,0.14,0.14],[1.871,0.121,0.114],[3.395,0.238,0.239],[0.089,0.003,0.002],[8.698,0.075,0.075],[10.16,0.039,0.036],[12.629,0.093,0.09],[6.742,0.163,0.166],[1.867,0.031,0.03],[0.958,0.027,0.026],[2.442,0.029,0.029],[9.118,0.074,0.071],[7.439,0.483,0.482],[0.086,0.059,0.058],[1.276,0.055,0.056],[4.775,0.071,0.069],[3.552,0.278,0.261],[8.67,0.309,0.293],[8.669,0.305,0.303],[0.087,0.036,0.035],[0.081,0.051,0.055],[0.048,0.03,0.029],[0.064,0.026,0.025],[0.142,0.085,0.095],[0.041,0.017,0.019],[0.036,0.015,0.014],[0.03,0.012,0.012]],"source":"clickhouse/results/c8g.metal-48xl.json"}
,{"system":"Cloudberry","date":"2024-06-06","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"14 segments, ORCA enabled","tags":["C","column-oriented","PostgreSQL compatible"],"load_time":601,"data_size":36000000000,"result":[[2.173,1.265,1.206],[0.465,0.516,0.456],[1.537,1.552,1.636],[1.313,1.475,1.150],[3.666,3.525,3.710],[4.230,4.263,4.112],[1.444,1.476,1.351],[0.481,0.455,0.453],[7.469,7.515,7.482],[8.219,8.232,8.276],[1.238,1.143,1.177],[1.530,1.420,1.495],[2.532,2.647,2.630],[4.742,4.896,4.932],[3.051,2.864,2.890],[4.568,4.588,4.536],[6.130,6.015,6.090],[2.713,2.379,2.235],[12.388,11.478,11.546],[0.360,0.274,0.272],[8.382,2.865,2.854],[9.455,3.028,2.988],[18.474,3.898,3.900],[51.404,11.556,11.570],[2.082,1.206,1.242],[1.323,1.090,1.073],[2.037,1.270,1.341],[8.625,5.870,5.960],[46.390,46.696,46.376],[12.753,12.556,12.646],[2.487,2.440,2.341],[5.187,3.177,3.145],[17.427,17.223,17.491],[69.981,58.394,61.582],[76.498,63.913,64.852],[6.558,6.414,6.468],[0.352,0.165,0.161],[0.164,0.102,0.101],[0.151,0.088,0.086],[0.313,0.267,0.263],[0.173,0.092,0.094],[0.171,0.098,0.096],[0.190,0.124,0.119]],"source":"cloudberry/results/c6a.4xlarge.json"}
,{"system":"CockroachDB","date":"2025-05-18","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"CockroachDB v25.1.6. Cache size: 25%.","tags":["Go","row-oriented","PostgreSQL compatible"],"load_time":813,"data_size":67948956585,"result":[[163.912,144.354,130.781],[209.559,201.121,180.182],[214.860,215.300,149.370],[192.729,177.878,174.889],[194.478,177.635,176.819],[233.523,217.995,215.710],[177.835,162.324,160.626],[218.716,203.230,201.820],[195.911,180.680,179.033],[280.607,273.138,265.288],[218.154,200.244,198.852],[215.733,201.223,198.272],[250.315,234.739,233.557],[316.434,297.867,296.487],[262.367,247.245,245.162],[220.332,205.042,203.623],[304.619,289.938,288.060],[239.883,224.987,223.489],[372.238,354.576,353.751],[189.723,174.461,172.702],[198.055,183.154,181.369],[229.319,214.270,212.659],[230.917,215.904,219.478],[380.171,364.246,363.680],[227.415,212.249,211.565],[229.333,210.662,212.035],[227.094,211.117,210.007],[219.566,204.239,202.582],[525.889,504.875,501.666],[525.665,508.762,506.737],[272.512,256.169,254.003],[287.183,271.501,268.979],[703.371,685.376,683.419],[336.557,320.592,319.017],[363.330,352.200,348.893],[253.869,239.249,236.849],[262.953,247.595,245.825],[261.543,246.544,244.704],[250.970,240.305,235.893],[237.548,223.112,221.408],[316.462,299.441,298.672],[313.563,299.774,297.671],[261.691,246.591,245.072]],"source":"cockroachdb/results/c6a.4xlarge.json"}
,{"system":"CockroachDB","date":"2025-07-12","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Go","row-oriented","PostgreSQL compatible"],"load_time":760,"data_size":67948956585,"result":[[161.359,144.702,141.795],[201.986,193,194.244],[202.265,186.614,153.441],[179.663,164.798,164.418],[180.588,168.517,167.012],[221.916,206.68,206.075],[167.34,152.985,153.333],[204.894,189.671,189.689],[186.487,172.467,172.285],[269.054,255.401,256.168],[202.291,187.381,187.298],[202.739,188.53,188.581],[242.358,229.787,232.298],[321.971,305.491,307.964],[251.928,238.428,240.617],[206.179,193.134,192.405],[297.352,282.552,282.887],[224.729,210.274,210.744],[363.996,356.816,353.177],[175.024,160.119,160.02],[182.579,169.046,169.826],[212.23,201.079,198.315],[216.422,200.322,202.255],[342.79,328.72,330.137],[210.084,195.279,194.959],[209.976,195.644,195.252],[209.462,195.027,195.509],[207.318,193.158,192.853],[505.323,490.265,492.709],[457.773,443.204,442.735],[252.723,237.471,237.492],[264.025,251.887,251.79],[637.786,620.721,621.348],[334.163,321.107,319.59],[362.098,350.984,351.632],[245.245,229.806,228.919],[242.333,223.756,226.242],[242.728,225.922,227.12],[234.619,222.184,221.356],[222.36,208.037,208.15],[276.084,260.478,260.329],[275.859,266.568,266.731],[242.353,223.23,227.298]],"source":"cockroachdb/results/c8g.4xlarge.json"}
@@ -198,40 +204,44 @@ const data = [
,{"system":"Drill","date":"2025-07-10","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","column-oriented","stateless"],"load_time":0,"data_size":14779976446,"result":[[2.016,0.341,0.302],[6.485,2.708,2.037],[7.032,3.269,2.705],[7.067,2.827,2.474],[12.536,6.449,5.695],[12.049,6.335,5.526],[null,null,null],[7.581,2.79,2.25],[13.88,7.96,6.895],[19.477,11.266,10.325],[8.988,3.651,2.977],[9.306,3.926,3.384],[12.707,6.088,5.595],[24.731,17.792,16.844],[12.948,6.812,6.089],[13.436,7.489,6.781],[20.472,11.988,11.233],[16.219,10.068,9.297],[30.242,23.023,22.223],[6.742,2.162,2.274],[14.929,7.219,7.131],[17.238,8.42,8.259],[29.061,11.667,11.102],[61.033,50.622,47.59],[10.401,5.226,4.457],[10.381,4.887,4.325],[11.155,5.847,4.956],[19.154,11.541,11.339],[38.51,30.231,30.826],[46.352,38.87,39.677],[14.241,6.808,6.345],[16.726,8.823,7.964],[45.224,36.382,35.987],[34.574,25.531,23.908],[35.067,27.085,25.583],[14.944,8.769,8.007],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null]],"source":"drill/results/c6a.2xlarge.json"}
,{"system":"Drill","date":"2025-07-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","column-oriented","stateless"],"load_time":0,"data_size":14779976446,"result":[[1.991,0.322,0.272],[6.141,1.676,1.52],[5.86,2.332,1.849],[5.951,2.11,1.614],[9.667,4.097,3.632],[10.071,4.107,3.688],[null,null,null],[6.861,1.78,1.767],[10.813,4.768,4.152],[15.604,7.022,6.366],[7.763,2.73,2.042],[7.988,2.653,2.082],[10.391,4.029,3.606],[29.132,22.304,21.676],[10.878,4.338,4.001],[10.644,4.644,4.081],[13.884,7.619,6.815],[12.556,6.424,5.551],[20.558,13.452,12.849],[6.066,1.809,1.381],[14.674,4.69,4.365],[16.898,4.926,4.467],[28.085,7.409,7.098],[60.177,24.119,24.568],[8.614,3.199,2.959],[8.448,3.142,2.777],[8.985,3.534,3.431],[16.734,7.533,7.063],[25.111,16.657,17.028],[31.001,22.746,21.632],[11.804,4.2,3.841],[14.659,5.423,4.77],[30.539,22.23,21.698],[24.019,16.997,16.879],[25.026,17.564,17.464],[11.715,5.669,4.662],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null],[null,null,null]],"source":"drill/results/c6a.4xlarge.json"}
,{"system":"Druid","date":"2022-07-01","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"Druid is killed and restarted after every query. Otherwise some queries make Druid degraded and results are incorrect. For example after Q13 even SELECT 1 works for 7 seconds","tags":["Java","column-oriented"],"load_time":19620,"data_size":45188608472,"result":[[0.032,0.016,0.016],[0.400,0.275,0.271],[0.382,0.152,0.151],[1.379,0.137,0.128],[3.278,2.527,2.515],[8.576,6.546,6.503],[null,null,null],[0.563,0.273,0.275],[11.509,10.636,10.597],[13.357,12.421,12.337],[1.636,0.821,0.900],[1.692,0.512,0.440],[2.453,1.769,1.807],[8.503,7.261,7.334],[61.056,59.251,59.500],[8.620,8.236,8.225],[164.840,null,null],[24.165,22.308,null],[null,null,null],[null,null,null],[25.973,25.597,25.602],[null,null,null],[null,null,null],[7.805,6.629,6.947],[0.257,0.020,0.016],[null,null,null],[null,null,null],[32.948,31.046,29.221],[null,null,null],[7.230,7.033,6.972],[20.546,19.237,19.258],[54.065,52.451,52.466],[null,null,null],[17.499,null,null],[null,null,null],[60.478,60.054,60.458],[1.698,1.490,1.461],[1.409,0.939,0.907],[0.866,0.329,0.287],[null,null,null],[0.932,0.420,0.359],[0.723,0.325,0.296],[0.603,0.150,0.140]],"source":"druid/results/c6a.4xlarge.json"}
-,{"system":"DuckDB (DataFrame)","date":"2025-09-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":82.77,"data_size":176641134592,"result":[[0.034,0.016,0.017],[0.035,0.022,0.024],[0.029,0.026,0.025],[0.066,0.026,0.031],[0.865,0.094,0.097],[0.171,0.151,0.166],[0.031,0.03,0.035],[0.022,0.023,0.025],[0.11,0.114,0.114],[0.14,0.141,0.143],[0.055,0.052,0.051],[0.07,0.054,0.056],[0.154,0.15,0.151],[0.199,0.194,0.197],[0.147,0.152,0.174],[0.108,0.106,0.104],[0.228,0.223,0.236],[0.245,0.254,0.236],[0.331,0.345,0.315],[0.053,0.03,0.031],[0.328,0.315,0.308],[0.329,0.332,0.355],[0.613,0.622,0.615],[1.396,1.1,1.104],[0.086,0.08,0.08],[0.075,0.076,0.075],[0.087,0.085,0.082],[0.308,0.322,0.308],[1.471,1.36,1.39],[0.037,0.037,0.033],[0.14,0.136,0.119],[0.186,0.141,0.139],[0.46,0.43,0.421],[0.57,0.563,0.615],[0.589,0.547,0.551],[0.132,0.127,0.131],[0.313,0.31,0.308],[0.371,0.363,0.358],[0.277,0.32,0.319],[0.455,0.421,0.446],[0.038,0.039,0.034],[0.035,0.036,0.038],[0.046,0.067,0.052]],"source":"duckdb-dataframe/results/c6a.metal.json"}
-,{"system":"DuckDB (DataFrame)","date":"2025-09-07","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":94,"data_size":178964828160,"result":[[0.027,0.015,0.017],[0.018,0.015,0.014],[0.017,0.017,0.017],[0.022,0.017,0.018],[0.243,0.169,0.162],[0.179,0.185,0.186],[0.023,0.02,0.021],[0.045,0.035,0.038],[0.202,0.204,0.202],[0.234,0.223,0.235],[0.104,0.108,0.104],[0.107,0.103,0.106],[0.176,0.182,0.171],[0.289,0.286,0.287],[0.181,0.187,0.187],[0.19,0.185,0.186],[0.411,0.374,0.376],[0.395,0.409,0.357],[0.49,0.476,0.468],[0.023,0.024,0.023],[0.224,0.271,0.254],[0.263,0.237,0.242],[0.487,0.479,0.478],[0.814,0.724,0.724],[0.053,0.053,0.051],[0.05,0.05,0.051],[0.056,0.055,0.055],[0.221,0.222,0.222],[1.066,1.071,1.09],[0.032,0.027,0.026],[0.163,0.14,0.148],[0.18,0.179,0.18],[0.574,0.55,0.545],[0.479,0.48,0.5],[0.47,0.472,0.476],[0.336,0.198,0.206],[0.215,0.207,0.209],[0.308,0.28,0.276],[0.199,0.207,0.21],[0.338,0.315,0.318],[0.022,0.023,0.021],[0.021,0.022,0.022],[0.026,0.025,0.024]],"source":"duckdb-dataframe/results/c7a.metal-48xl.json"}
-,{"system":"DuckDB (DataFrame)","date":"2025-09-07","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":76,"data_size":180664000512,"result":[[0.023,0.016,0.016],[0.019,0.017,0.017],[0.036,0.018,0.018],[0.103,0.019,0.018],[0.161,0.137,0.137],[0.159,0.159,0.153],[0.024,0.02,0.02],[0.033,0.037,0.042],[0.205,0.185,0.181],[0.211,0.197,0.203],[0.078,0.072,0.076],[0.078,0.078,0.079],[0.138,0.139,0.141],[0.244,0.238,0.246],[0.146,0.142,0.144],[0.159,0.17,0.167],[0.336,0.281,0.256],[0.265,0.253,0.255],[0.317,0.321,0.311],[0.022,0.02,0.019],[0.275,0.29,0.272],[0.285,0.279,0.281],[0.465,0.465,0.461],[0.735,0.73,0.739],[0.047,0.048,0.048],[0.051,0.046,0.048],[0.05,0.049,0.052],[0.265,0.262,0.261],[0.843,0.861,0.872],[0.029,0.024,0.027],[0.149,0.128,0.126],[0.187,0.164,0.173],[0.447,0.424,0.405],[0.461,0.447,0.444],[0.43,0.429,0.425],[0.163,0.172,0.171],[0.259,0.262,0.269],[0.246,0.246,0.244],[0.248,0.252,0.248],[0.369,0.362,0.364],[0.025,0.023,0.022],[0.022,0.023,0.022],[0.025,0.027,0.027]],"source":"duckdb-dataframe/results/c8g.metal-48xl.json"}
+,{"system":"DuckDB (DataFrame)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":82,"data_size":182961963008,"result":[[0.031,0.016,0.016],[0.033,0.019,0.017],[0.027,0.023,0.023],[0.057,0.023,0.025],[0.806,0.089,0.088],[0.151,0.164,0.164],[0.031,0.027,0.031],[0.023,0.026,0.025],[0.107,0.106,0.11],[0.136,0.14,0.138],[0.054,0.054,0.055],[0.062,0.057,0.058],[0.143,0.142,0.152],[0.186,0.173,0.176],[0.175,0.162,0.161],[0.103,0.104,0.101],[0.22,0.227,0.22],[0.24,0.24,0.23],[0.326,0.326,0.319],[0.057,0.03,0.033],[0.622,0.299,0.308],[0.309,0.341,0.318],[0.65,0.608,0.615],[1.047,0.978,0.969],[0.067,0.064,0.065],[0.064,0.064,0.065],[0.069,0.069,0.066],[0.296,0.324,0.313],[1.475,1.469,1.353],[0.039,0.034,0.035],[0.137,0.117,0.105],[0.196,0.122,0.128],[0.459,0.435,0.42],[0.585,0.567,0.598],[0.547,0.566,0.581],[0.131,0.128,0.128],[0.321,0.277,0.308],[0.376,0.366,0.371],[0.273,0.283,0.291],[0.418,0.415,0.41],[0.04,0.032,0.036],[0.043,0.043,0.043],[0.041,0.059,0.046]],"source":"duckdb-dataframe/results/c6a.metal.json"}
+,{"system":"DuckDB (DataFrame)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":93,"data_size":175929663488,"result":[[0.025,0.02,0.015],[0.019,0.019,0.022],[0.023,0.018,0.018],[0.018,0.022,0.016],[0.714,0.068,0.067],[0.123,0.123,0.121],[0.02,0.018,0.017],[0.022,0.021,0.021],[0.075,0.079,0.077],[0.099,0.099,0.095],[0.037,0.041,0.039],[0.039,0.039,0.043],[0.119,0.124,0.12],[0.137,0.136,0.132],[0.118,0.122,0.125],[0.079,0.075,0.075],[0.163,0.163,0.158],[0.161,0.17,0.173],[0.234,0.224,0.216],[0.036,0.024,0.022],[0.23,0.231,0.235],[0.241,0.245,0.242],[0.478,0.48,0.478],[0.807,0.728,0.728],[0.055,0.051,0.051],[0.05,0.05,0.049],[0.054,0.054,0.054],[0.223,0.224,0.225],[1.155,0.987,0.913],[0.023,0.022,0.021],[0.08,0.095,0.08],[0.09,0.1,0.088],[0.385,0.345,0.301],[0.431,0.374,0.366],[0.37,0.364,0.353],[0.094,0.091,0.087],[0.215,0.216,0.218],[0.279,0.276,0.271],[0.209,0.211,0.214],[0.327,0.324,0.322],[0.028,0.023,0.022],[0.021,0.025,0.027],[0.025,0.037,0.024]],"source":"duckdb-dataframe/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB (DataFrame)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","Python","dataframe"],"load_time":73,"data_size":176077402112,"result":[[0.031,0.017,0.018],[0.022,0.019,0.022],[0.025,0.019,0.021],[0.021,0.025,0.023],[0.442,0.068,0.067],[0.116,0.111,0.112],[0.025,0.024,0.023],[0.024,0.026,0.028],[0.078,0.077,0.095],[0.094,0.092,0.091],[0.043,0.039,0.04],[0.041,0.041,0.042],[0.109,0.108,0.118],[0.137,0.135,0.131],[0.117,0.122,0.113],[0.073,0.075,0.071],[0.174,0.177,0.167],[0.178,0.189,0.186],[0.235,0.209,0.206],[0.045,0.021,0.02],[0.274,0.273,0.273],[0.279,0.28,0.276],[0.46,0.452,0.455],[0.762,0.73,0.731],[0.051,0.053,0.049],[0.048,0.053,0.049],[0.052,0.052,0.054],[0.262,0.261,0.262],[0.876,0.817,0.785],[0.03,0.025,0.028],[0.076,0.072,0.071],[0.092,0.086,0.087],[0.322,0.268,0.252],[0.43,0.453,0.425],[0.412,0.425,0.404],[0.087,0.08,0.082],[0.257,0.255,0.255],[0.244,0.243,0.242],[0.252,0.254,0.253],[0.368,0.368,0.364],[0.031,0.026,0.024],[0.027,0.027,0.027],[0.031,0.048,0.031]],"source":"duckdb-dataframe/results/c8g.metal-48xl.json"}
,{"system":"DuckDB (data lake, partitioned)","date":"2025-07-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.089,0.002,0.002],[0.077,0.016,0.015],[0.161,0.057,0.056],[0.481,0.053,0.053],[1.232,0.313,0.307],[0.955,0.427,0.415],[0.082,0.027,0.028],[0.086,0.017,0.017],[0.835,0.409,0.415],[1.172,0.512,0.51],[0.563,0.097,0.091],[1.011,0.112,0.107],[1.414,0.421,0.419],[2.564,0.701,0.705],[1.007,0.456,0.47],[0.639,0.377,0.383],[2.564,0.912,0.935],[2.328,0.708,0.719],[4.781,1.647,1.646],[0.124,0.019,0.018],[10.015,0.683,0.68],[11.217,0.618,0.612],[19.567,1.301,1.301],[3.791,0.752,0.843],[0.193,0.086,0.089],[1.037,0.218,0.216],[0.159,0.068,0.066],[9.965,0.566,0.57],[9.779,9.531,9.567],[0.139,0.05,0.374],[2.422,0.463,0.477],[6.21,0.574,0.585],[5.599,1.909,1.914],[10.052,2.076,2.075],[10.074,2.137,2.136],[0.686,0.538,0.55],[0.173,0.083,0.086],[0.12,0.063,0.062],[0.123,0.035,0.03],[0.333,0.183,0.136],[0.085,0.019,0.018],[0.08,0.019,0.018],[0.077,0.02,0.023]],"source":"duckdb-datalake-partitioned/results/c6a.4xlarge.json"}
,{"system":"DuckDB (data lake, single)","date":"2025-07-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.089,0.002,0.002],[0.077,0.016,0.015],[0.161,0.057,0.056],[0.481,0.053,0.053],[1.232,0.313,0.307],[0.955,0.427,0.415],[0.082,0.027,0.028],[0.086,0.017,0.017],[0.835,0.409,0.415],[1.172,0.512,0.51],[0.563,0.097,0.091],[1.011,0.112,0.107],[1.414,0.421,0.419],[2.564,0.701,0.705],[1.007,0.456,0.47],[0.639,0.377,0.383],[2.564,0.912,0.935],[2.328,0.708,0.719],[4.781,1.647,1.646],[0.124,0.019,0.018],[10.015,0.683,0.68],[11.217,0.618,0.612],[19.567,1.301,1.301],[3.791,0.752,0.843],[0.193,0.086,0.089],[1.037,0.218,0.216],[0.159,0.068,0.066],[9.965,0.566,0.57],[9.779,9.531,9.567],[0.139,0.05,0.374],[2.422,0.463,0.477],[6.21,0.574,0.585],[5.599,1.909,1.914],[10.052,2.076,2.075],[10.074,2.137,2.136],[0.686,0.538,0.55],[0.173,0.083,0.086],[0.12,0.063,0.062],[0.123,0.035,0.03],[0.333,0.183,0.136],[0.085,0.019,0.018],[0.08,0.019,0.018],[0.077,0.02,0.023]],"source":"duckdb-datalake/results/c6a.4xlarge.json"}
-,{"system":"DuckDB (memory)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":467,"data_size":14749884416,"result":[[0.057,0.008,0.008],[0.673,0.039,0.041],[1.131,0.08,0.089],[3.08,0.272,0.036],[1.125,0.969,0.814],[5.014,2.004,0.877],[1.892,0.043,0.042],[0.724,0.025,0.025],[3.574,1.544,1.131],[2.433,1.65,1.224],[2.335,0.225,0.222],[1.413,0.338,0.394],[3.276,0.97,0.75],[2.461,1.496,1.314],[2.161,0.752,0.716],[0.771,0.699,0.691],[2,1.961,1.631],[1.258,1.187,1.15],[8.156,6.289,4.46],[0.082,0.019,0.051],[33.821,15.792,14.673],[17.425,15.159,13.737],[64.011,61.208,54.778],[8.477,0.625,0.387],[0.749,0.056,0.072],[0.527,0.291,0.13],[0.075,0.065,0.08],[24.991,21.574,17.536],[40.586,29.164,23.899],[0.285,0.024,0.024],[9.808,4.569,2.973],[9.202,8.027,6.726],[18.566,9.014,6.547],[25.287,18.587,12.495],[11.048,10.07,10.316],[1.377,1.089,0.931],[0.088,0.027,0.022],[0.105,0.054,0.02],[0.025,0.007,0.007],[0.135,0.045,0.045],[0.196,0.013,0.007],[0.035,0.007,0.007],[0.03,0.011,0.011]],"source":"duckdb-memory/results/c6a.2xlarge.json"}
-,{"system":"DuckDB (memory)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":281.689,"data_size":28136767488,"result":[[0.032,0.003,0.003],[0.009,0.01,0.005],[0.03,0.022,0.022],[0.041,0.034,0.033],[0.371,0.364,0.366],[0.374,0.335,0.32],[0.006,0.005,0.005],[0.018,0.006,0.006],[0.4,0.402,0.401],[0.554,0.554,0.552],[0.082,0.081,0.079],[0.085,0.088,0.088],[0.366,0.351,0.35],[0.701,0.693,0.674],[0.395,0.392,0.388],[0.37,0.36,0.356],[0.862,0.817,0.832],[0.633,0.638,0.615],[1.584,1.57,1.563],[0.008,0.012,0.007],[0.546,0.521,0.501],[0.499,0.498,0.501],[0.766,0.677,0.682],[0.084,0.08,0.08],[0.02,0.02,0.02],[0.075,0.07,0.069],[0.021,0.015,0.015],[0.409,0.407,0.405],[6.503,6.472,6.45],[0.033,0.03,0.032],[0.301,0.3,0.299],[0.39,0.369,0.374],[1.826,1.753,1.744],[1.805,1.777,1.779],[1.959,1.955,1.934],[0.476,0.505,0.538],[0.075,0.027,0.042],[0.038,0.015,0.027],[0.016,0.035,0.046],[0.078,0.11,0.062],[0.028,0.006,0.009],[0.008,0.009,0.007],[0.021,0.02,0.013]],"source":"duckdb-memory/results/c6a.4xlarge.json"}
-,{"system":"DuckDB (memory)","date":"2025-09-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":15.244,"data_size":109925945344,"result":[[0.012,0.027,0.004],[0.005,0.011,0.035],[0.096,0.008,0.006],[0.099,0.007,0.006],[0.177,0.248,0.183],[0.208,0.193,0.26],[0.009,0.004,0.004],[0.033,0.088,0.006],[0.208,0.268,0.178],[0.217,0.307,0.307],[0.086,0.111,0.055],[0.059,0.068,0.074],[0.103,0.119,0.121],[0.25,0.173,0.283],[0.122,0.133,0.142],[0.099,0.099,0.1],[0.168,0.169,0.169],[0.171,0.185,0.184],[0.317,0.31,0.306],[0.006,0.005,0.004],[0.104,0.077,0.073],[0.074,0.072,0.074],[0.098,0.091,0.095],[0.074,0.07,0.063],[0.011,0.013,0.013],[0.031,0.034,0.032],[0.011,0.011,0.012],[0.073,0.075,0.074],[1.195,1.103,1.06],[0.024,0.019,0.023],[0.094,0.09,0.082],[0.106,0.096,0.097],[0.471,0.436,0.445],[0.366,0.323,0.346],[0.351,0.366,0.351],[0.105,0.098,0.107],[0.022,0.021,0.023],[0.015,0.006,0.011],[0.016,0.016,0.012],[0.04,0.045,0.038],[0.007,0.005,0.008],[0.006,0.014,0.006],[0.008,0.01,0.019]],"source":"duckdb-memory/results/c6a.metal.json"}
-,{"system":"DuckDB (memory)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":23,"data_size":119273459712,"result":[[0.025,0.024,0.025],[0.027,0.016,0.01],[0.028,0.028,0.027],[0.026,0.026,0.026],[0.163,0.155,0.164],[0.175,0.165,0.165],[0.029,0.026,0.026],[0.02,0.018,0.012],[0.19,0.2,0.197],[0.248,0.227,0.219],[0.114,0.111,0.113],[0.116,0.115,0.113],[0.171,0.171,0.177],[0.309,0.366,0.364],[0.192,0.176,0.174],[0.194,0.194,0.233],[0.358,0.374,0.339],[0.356,0.355,0.371],[1.086,0.489,0.488],[0.026,0.024,0.029],[0.14,0.05,0.051],[0.123,0.071,0.06],[0.289,0.161,0.117],[0.106,0.087,0.083],[0.052,0.053,0.049],[0.041,0.04,0.04],[0.088,0.039,0.037],[0.112,0.099,0.1],[1.297,0.967,0.911],[0.067,0.034,0.049],[0.168,0.138,0.138],[0.339,0.206,0.198],[0.682,0.619,0.61],[0.652,0.5,0.478],[0.501,0.529,0.517],[0.207,0.206,0.21],[0.057,0.051,0.039],[0.064,0.039,0.045],[0.043,0.038,0.036],[0.054,0.042,0.051],[0.033,0.029,0.035],[0.026,0.015,0.039],[0.028,0.019,0.027]],"source":"duckdb-memory/results/c7a.metal-48xl.json"}
-,{"system":"DuckDB (memory)","date":"2025-08-30","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":452,"data_size":27880833024,"result":[[0.014,0.011,0.011],[0.487,0.009,0.006],[0.839,0.025,0.025],[1.864,0.059,0.039],[0.469,0.302,0.279],[2.879,0.29,0.312],[1.071,0.016,0.015],[0.016,0.008,0.008],[1.464,0.527,0.425],[0.77,0.522,0.499],[1.183,0.055,0.056],[0.723,0.084,0.082],[0.461,0.283,0.235],[0.821,0.593,0.705],[0.938,0.244,0.244],[0.301,0.234,0.228],[0.826,0.689,0.578],[0.45,0.439,0.419],[6.383,2.783,1.376],[0.021,0.013,0.013],[28.216,5.469,2.837],[4.621,3.613,3.251],[44.986,35.717,38.189],[5.216,1.807,1.517],[0.423,0.044,0.042],[0.214,0.015,0.059],[0.105,0.019,0.014],[14.239,7.678,5.802],[28.327,15.648,7.576],[0.457,0.025,0.023],[7.801,1.677,1.154],[5.424,3.968,1.93],[13.277,5.48,2.002],[15.985,7.85,3.261],[2.837,2.41,2.076],[1.106,0.31,0.3],[0.03,0.02,0.022],[0.095,0.01,0.018],[0.015,0.015,0.005],[0.059,0.034,0.03],[0.191,0.004,0.004],[0.022,0.012,0.004],[0.017,0.005,0.007]],"source":"duckdb-memory/results/c8g.4xlarge.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.104,0.002,0.001],[0.12,0.034,0.034],[0.252,0.099,0.098],[0.741,0.085,0.084],[1.872,0.597,0.597],[1.498,0.807,0.828],[0.142,0.081,0.08],[0.101,0.037,0.036],[1.291,0.826,0.826],[1.806,1.03,1.039],[0.825,0.19,0.189],[1.656,0.223,0.22],[2.101,0.82,0.816],[3.52,1.263,1.261],[1.52,0.908,0.904],[0.953,0.648,0.652],[3.476,1.683,1.699],[3.258,1.329,1.334],[6.516,3.099,3.155],[0.165,0.021,0.02],[11.809,1.637,1.629],[12.093,1.564,1.544],[23.465,3.137,3.158],[4.198,0.893,1.115],[0.307,0.176,0.174],[1.575,0.485,0.488],[0.261,0.136,0.141],[11.225,1.37,1.385],[18.235,17.856,17.835],[0.22,0.282,0.102],[2.441,0.903,0.922],[6.253,1.036,1.047],[6.309,3.393,3.352],[10.147,3.288,3.297],[10.164,3.468,3.54],[1.269,1.122,1.133],[0.164,0.102,0.087],[0.119,0.078,0.082],[0.124,0.094,0.135],[0.355,0.191,0.2],[0.08,0.018,0.019],[0.077,0.019,0.02],[0.08,0.033,0.034]],"source":"duckdb-parquet-partitioned/results/c6a.2xlarge.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.089,0.002,0.001],[0.075,0.021,0.021],[0.151,0.053,0.052],[0.612,0.048,0.047],[1.053,0.290,0.288],[0.981,0.470,0.463],[0.084,0.044,0.043],[0.080,0.022,0.023],[0.836,0.413,0.417],[1.162,0.523,0.525],[0.551,0.105,0.104],[1.048,0.125,0.121],[1.420,0.489,0.495],[2.601,0.821,0.822],[0.995,0.540,0.533],[0.638,0.381,0.378],[2.589,0.981,1.010],[2.334,0.725,0.723],[4.817,1.820,1.854],[0.153,0.022,0.020],[10.012,0.862,0.856],[11.201,0.799,0.801],[19.869,1.655,1.635],[3.773,0.407,0.395],[0.196,0.100,0.106],[1.095,0.241,0.246],[0.159,0.077,0.080],[10.042,0.736,0.718],[8.992,8.638,8.658],[0.148,0.052,0.050],[2.391,0.499,0.504],[6.177,0.597,0.605],[5.468,1.868,1.878],[10.079,2.192,2.200],[10.088,2.238,2.240],[0.721,0.594,0.600],[0.184,0.096,0.103],[0.122,0.078,0.077],[0.120,0.047,0.048],[0.358,0.183,0.193],[0.078,0.020,0.020],[0.075,0.020,0.019],[0.083,0.033,0.031]],"source":"duckdb-parquet-partitioned/results/c6a.4xlarge.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":426,"data_size":14791049216,"result":[[0.075,0.004,0.004],[0.051,0.052,0.007],[0.077,0.04,0.039],[0.125,0.06,0.059],[0.562,0.525,0.536],[0.702,0.564,0.557],[0.032,0.01,0.01],[0.028,0.011,0.013],[0.733,0.712,0.711],[0.969,0.96,0.973],[0.18,0.147,0.146],[0.192,0.167,0.167],[0.83,0.653,0.584],[1.369,1.174,1.145],[0.657,0.687,0.64],[0.639,0.631,0.63],[1.726,1.509,1.49],[1.116,1.073,1.084],[7.857,4.654,3.075],[0.019,0.035,0.028],[4.403,0.965,0.962],[0.99,0.989,0.985],[2.282,1.363,1.509],[0.208,0.152,0.152],[0.033,0.035,0.032],[0.135,0.136,0.135],[0.025,0.024,0.023],[0.813,0.786,0.787],[14.269,14.426,13.367],[0.088,0.053,0.055],[0.618,0.51,0.51],[2.121,1.293,0.828],[19.911,9.243,3.885],[8.613,4.387,3.521],[3.837,4.479,4.349],[0.983,1.109,0.814],[0.041,0.028,0.026],[0.012,0.009,0.008],[0.015,0.013,0.014],[0.078,0.061,0.06],[0.02,0.008,0.006],[0.013,0.006,0.007],[0.02,0.012,0.013]],"source":"duckdb-memory/results/c6a.2xlarge.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":283,"data_size":28254740480,"result":[[0.029,0.002,0.002],[0.067,0.004,0.004],[0.022,0.02,0.02],[0.031,0.03,0.03],[0.314,0.303,0.295],[0.326,0.312,0.31],[0.007,0.005,0.005],[0.016,0.009,0.008],[0.398,0.395,0.394],[0.552,0.544,0.552],[0.082,0.076,0.084],[0.095,0.09,0.09],[0.352,0.345,0.342],[0.702,0.686,0.667],[0.384,0.379,0.381],[0.362,0.351,0.366],[0.854,0.822,0.843],[0.659,0.639,0.634],[1.573,1.553,1.536],[0.013,0.007,0.008],[0.539,0.523,0.493],[0.489,0.487,0.49],[0.688,0.721,0.703],[0.08,0.076,0.078],[0.019,0.019,0.018],[0.068,0.068,0.067],[0.016,0.015,0.014],[0.402,0.404,0.395],[6.431,6.397,6.414],[0.035,0.031,0.136],[0.296,0.295,0.296],[0.378,0.375,0.368],[1.802,1.724,1.809],[1.769,1.733,1.743],[1.917,1.926,1.921],[0.454,0.468,0.457],[0.078,0.026,0.037],[0.017,0.012,0.024],[0.013,0.016,0.037],[0.066,0.058,0.054],[0.156,0.064,0.019],[0.007,0.01,0.006],[0.016,0.013,0.017]],"source":"duckdb-memory/results/c6a.4xlarge.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":15,"data_size":109959671808,"result":[[0.012,0.004,0.003],[0.004,0.003,0.03],[0.306,0.012,0.005],[0.31,0.007,0.006],[0.156,0.101,0.14],[0.153,0.102,0.169],[0.007,0.004,0.004],[0.008,0.005,0.004],[0.123,0.162,0.122],[0.144,0.172,0.154],[0.039,0.05,0.03],[0.034,0.034,0.036],[0.112,0.107,0.116],[0.27,0.253,0.294],[0.114,0.126,0.123],[0.107,0.11,0.103],[0.227,0.171,0.159],[0.175,0.186,0.208],[0.33,0.308,0.307],[0.006,0.003,0.003],[0.083,0.075,0.078],[0.073,0.074,0.069],[0.091,0.1,0.115],[0.093,0.073,0.071],[0.012,0.012,0.012],[0.033,0.03,0.034],[0.012,0.012,0.023],[0.072,0.065,0.069],[1.194,1.067,1.086],[0.03,0.024,0.03],[0.108,0.094,0.079],[0.105,0.109,0.095],[0.494,0.438,0.474],[0.379,0.355,0.336],[0.379,0.382,0.43],[0.114,0.106,0.103],[0.025,0.034,0.021],[0.01,0.011,0.011],[0.01,0.012,0.022],[0.059,0.038,0.049],[0.015,0.01,0.019],[0.01,0.015,0.009],[0.016,0.01,0.013]],"source":"duckdb-memory/results/c6a.metal.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":12,"data_size":110490939392,"result":[[0.022,0.004,0.003],[0.019,0.049,0.022],[0.061,0.026,0.006],[0.062,0.006,0.004],[0.267,0.139,0.17],[0.18,0.191,0.181],[0.007,0.003,0.003],[0.048,0.06,0.006],[0.182,0.191,0.106],[0.163,0.187,0.138],[0.095,0.066,0.051],[0.029,0.028,0.057],[0.089,0.087,0.122],[0.132,0.223,0.218],[0.106,0.091,0.092],[0.076,0.077,0.078],[0.171,0.123,0.125],[0.127,0.13,0.131],[0.223,0.219,0.219],[0.006,0.004,0.005],[0.085,0.061,0.052],[0.057,0.051,0.047],[0.067,0.067,0.066],[0.063,0.054,0.053],[0.01,0.012,0.011],[0.028,0.029,0.028],[0.01,0.009,0.009],[0.052,0.051,0.041],[0.987,0.785,0.726],[0.016,0.013,0.014],[0.068,0.059,0.057],[0.099,0.07,0.073],[0.413,0.404,0.369],[0.33,0.299,0.314],[0.253,0.237,0.241],[0.084,0.083,0.085],[0.021,0.016,0.021],[0.01,0.01,0.012],[0.013,0.009,0.019],[0.042,0.04,0.037],[0.006,0.008,0.01],[0.008,0.012,0.01],[0.01,0.011,0.011]],"source":"duckdb-memory/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":288,"data_size":27818287104,"result":[[0.405,0.003,0.002],[0.007,0.007,0.003],[0.093,0.014,0.013],[0.022,0.021,0.021],[0.328,0.168,0.166],[0.179,0.165,0.178],[0.005,0.004,0.004],[0.088,0.004,0.007],[0.21,0.216,0.216],[0.316,0.313,0.309],[0.061,0.049,0.056],[0.051,0.06,0.055],[0.183,0.197,0.186],[0.356,0.369,0.333],[0.199,0.196,0.195],[0.258,0.183,0.184],[0.427,0.409,0.422],[0.343,0.347,0.347],[0.764,0.74,0.731],[0.004,0.01,0.007],[0.34,0.333,0.325],[0.307,0.302,0.302],[0.379,0.407,0.46],[0.058,0.066,0.065],[0.013,0.012,0.012],[0.042,0.04,0.041],[0.01,0.009,0.009],[0.224,0.224,0.225],[3.68,3.673,3.651],[0.029,0.025,0.026],[0.184,0.165,0.165],[0.204,0.201,0.206],[0.858,0.768,0.785],[0.87,0.849,0.838],[0.946,0.95,0.954],[0.246,0.241,0.241],[0.069,0.038,0.015],[0.016,0.019,0.005],[0.016,0.031,0.008],[0.123,0.042,0.064],[0.03,0.007,0.004],[0.008,0.004,0.025],[0.165,0.022,0.01]],"source":"duckdb-memory/results/c8g.4xlarge.json"}
+,{"system":"DuckDB (memory)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":13,"data_size":107791679488,"result":[[0.011,0.002,0.002],[0.017,0.049,0.096],[0.003,0.336,0.003],[0.203,0.003,0.003],[0.326,0.344,0.59],[0.685,0.305,0.314],[0.005,0.003,0.003],[0.259,0.004,0.007],[0.591,0.578,0.221],[0.092,0.091,0.088],[0.023,0.021,0.02],[0.023,0.025,0.023],[0.08,0.078,0.077],[0.193,0.197,0.21],[0.089,0.079,0.092],[0.061,0.061,0.068],[0.111,0.127,0.1],[0.104,0.102,0.11],[0.225,0.218,0.196],[0.003,0.002,0.002],[0.072,0.052,0.048],[0.044,0.044,0.042],[0.062,0.061,0.059],[0.068,0.062,0.054],[0.01,0.01,0.012],[0.037,0.037,0.038],[0.012,0.011,0.01],[0.049,0.037,0.037],[0.627,0.563,0.543],[0.015,0.014,0.012],[0.056,0.048,0.047],[0.078,0.061,0.061],[0.37,0.289,0.342],[0.435,0.384,0.244],[0.201,0.198,0.198],[0.07,0.063,0.063],[0.015,0.021,0.017],[0.008,0.007,0.011],[0.011,0.011,0.012],[0.036,0.04,0.033],[0.015,0.005,0.008],[0.007,0.011,0.007],[0.007,0.007,0.007]],"source":"duckdb-memory/results/c8g.metal-48xl.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.081,0.002,0.001],[0.1,0.036,0.035],[0.22,0.099,0.097],[0.665,0.085,0.082],[1.724,0.479,0.483],[1.513,0.811,0.807],[0.15,0.079,0.079],[0.134,0.037,0.037],[1.204,0.695,0.7],[1.688,0.893,0.912],[0.789,0.187,0.184],[1.552,0.222,0.219],[2.029,0.818,0.826],[3.44,1.263,1.264],[1.437,0.902,0.901],[0.897,0.571,0.585],[3.43,1.606,1.61],[3.107,1.255,1.324],[6.019,3.031,3.036],[0.2,0.021,0.021],[10.926,1.64,1.628],[12.203,1.529,1.513],[21.503,3.197,3.235],[4.177,1.006,1.059],[0.295,0.17,0.17],[1.546,0.488,0.487],[0.265,0.134,0.141],[10.815,1.384,1.396],[18.871,18.472,18.488],[0.223,0.287,0.372],[2.422,0.9,0.935],[6.241,1.016,1.044],[6.043,3.008,3.141],[10.176,3.287,3.26],[10.211,3.333,3.378],[1.227,1.041,1.051],[0.182,0.103,0.099],[0.132,0.08,0.079],[0.125,0.049,0.047],[0.359,0.24,0.203],[0.089,0.022,0.018],[0.078,0.019,0.02],[0.084,0.034,0.036]],"source":"duckdb-parquet-partitioned/results/c6a.2xlarge.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.225,0.001,0.001],[0.218,0.021,0.02],[0.353,0.052,0.053],[0.821,0.049,0.046],[1.445,0.287,0.286],[1.771,0.478,0.476],[0.261,0.043,0.042],[0.07,0.022,0.021],[1.027,0.407,0.408],[1.715,0.518,0.528],[0.765,0.107,0.104],[1.564,0.125,0.122],[1.824,0.492,0.501],[2.937,0.84,0.823],[1.28,0.55,0.537],[0.786,0.375,0.378],[3.136,0.961,0.979],[2.681,0.757,0.747],[5.54,1.843,1.854],[0.133,0.021,0.02],[11.074,0.849,0.847],[11.849,0.815,0.798],[22.489,1.76,1.768],[4.353,0.808,0.792],[0.275,0.111,0.113],[1.378,0.253,0.259],[0.326,0.081,0.077],[10.898,0.718,0.734],[12.059,9.546,9.525],[0.263,0.165,0.056],[3.045,0.52,0.554],[7.638,0.612,0.651],[6.084,1.824,1.837],[10.725,2.185,2.17],[10.731,2.222,2.239],[0.73,0.6,0.617],[0.156,0.107,0.099],[0.121,0.082,0.079],[0.109,0.049,0.047],[0.357,0.183,0.214],[0.212,0.019,0.02],[0.067,0.019,0.019],[0.079,0.034,0.032]],"source":"duckdb-parquet-partitioned/results/c6a.4xlarge.json"}
,{"system":"DuckDB (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.164,0.001,0.002],[0.354,0.127,0.127],[0.965,0.384,0.382],[1.164,0.322,0.321],[4.125,3.353,3.357],[4.115,3.222,3.302],[0.527,0.312,0.312],[0.411,0.133,0.132],[5.082,4.255,4.269],[6.222,5.048,5.103],[1.667,0.648,0.643],[1.93,0.776,0.773],[4.032,3.205,3.187],[6.681,5.318,5.335],[4.682,3.712,3.693],[4.537,3.747,3.759],[9.04,7.798,7.8],[8.97,7.745,7.679],[22.858,23.486,23.581],[0.721,0.061,0.059],[9.518,6.341,6.564],[11.223,5.85,5.835],[20.219,15.646,15.282],[3.796,2.695,3.281],[0.974,0.545,0.525],[2.627,1.877,1.873],[0.838,0.468,0.469],[9.56,5.345,5.419],[69.847,68.791,68.768],[0.79,0.825,0.777],[5.603,3.666,3.746],[8.083,4.608,4.667],[33.562,34.383,34.427],[25.34,25.169,25.92],[26.122,26.013,26.6],[5.384,4.855,4.906],[0.316,0.11,0.176],[0.247,0.109,0.116],[0.264,0.101,0.147],[0.494,0.312,0.371],[0.225,0.032,0.03],[0.216,0.035,0.03],[0.225,0.042,0.041]],"source":"duckdb-parquet-partitioned/results/c6a.large.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-09-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.113,0.002,0.001],[0.089,0.022,0.021],[0.112,0.026,0.024],[0.313,0.028,0.026],[0.971,0.101,0.093],[0.939,0.179,0.177],[0.082,0.020,0.020],[0.108,0.028,0.027],[0.607,0.135,0.115],[1.037,0.143,0.144],[0.392,0.056,0.048],[0.880,0.055,0.050],[1.185,0.195,0.179],[2.083,0.243,0.209],[0.832,0.211,0.189],[0.569,0.119,0.105],[2.075,0.306,0.223],[2.079,0.242,0.284],[3.927,0.364,0.351],[0.119,0.019,0.021],[9.635,0.213,0.202],[10.934,0.252,0.174],[19.563,0.605,0.321],[3.659,2.772,0.332],[0.190,0.083,0.083],[0.892,0.078,0.069],[0.193,0.325,0.056],[9.914,0.217,0.187],[8.596,1.523,1.558],[0.104,0.032,0.027],[2.117,0.142,0.132],[5.671,0.205,0.166],[4.357,0.509,0.457],[9.688,0.545,0.522],[9.498,0.724,0.522],[0.422,0.169,0.337],[0.196,0.103,0.101],[0.142,0.076,0.077],[0.152,0.050,0.051],[0.336,0.208,0.193],[0.115,0.024,0.027],[0.117,0.029,0.028],[0.111,0.032,0.031]],"source":"duckdb-parquet-partitioned/results/c6a.metal.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":1,"data_size":14737666736,"result":[[0.105,0.002,0.001],[0.179,0.065,0.066],[0.453,0.195,0.193],[0.744,0.166,0.164],[1.946,1.129,1.119],[2.046,1.573,1.58],[0.275,0.158,0.157],[0.218,0.069,0.068],[1.957,1.529,1.525],[2.559,1.923,1.953],[0.921,0.361,0.356],[1.478,0.425,0.422],[2.102,1.544,1.551],[4.167,2.44,2.447],[2.28,1.735,1.733],[1.626,1.23,1.236],[4.325,3.416,3.439],[3.668,2.694,2.681],[8.115,6.204,6.29],[0.372,0.036,0.033],[10.986,3.208,3.201],[11.205,2.956,2.95],[19.644,6.428,6.394],[3.724,1.347,1.973],[0.494,0.315,0.303],[1.34,0.944,0.944],[0.478,0.256,0.258],[9.567,2.704,2.714],[36.076,35.249,35.332],[0.409,0.228,0.225],[2.777,1.745,1.815],[6.403,1.975,2.007],[8.38,7.59,7.725],[10.631,8.047,7.785],[10.695,8.373,7.701],[2.486,2.162,2.177],[0.191,0.103,0.15],[0.151,0.081,0.133],[0.146,0.055,0.052],[0.363,0.285,0.187],[0.125,0.024,0.023],[0.128,0.025,0.021],[0.13,0.036,0.035]],"source":"duckdb-parquet-partitioned/results/c6a.xlarge.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.107,0.002,0.001],[0.068,0.016,0.016],[0.086,0.017,0.016],[1.345,0.019,0.016],[1.395,0.149,0.141],[1.796,0.156,0.145],[0.063,0.015,0.015],[0.088,0.027,0.025],[1.65,0.182,0.169],[1.786,0.18,0.181],[1.263,0.044,0.046],[1.456,0.05,0.044],[1.722,0.159,0.161],[3.035,0.285,0.285],[1.636,0.172,0.16],[1.266,0.165,0.161],[2.991,0.322,0.29],[2.798,0.261,0.411],[4.751,0.406,0.495],[0.438,0.015,0.014],[10.49,0.205,0.209],[11.897,0.257,0.203],[20.827,0.639,0.376],[4.826,3.588,0.311],[0.862,0.079,0.08],[1.704,0.076,0.064],[2.022,0.06,0.05],[10.447,0.176,0.164],[9.364,1.641,1.616],[0.095,0.021,0.02],[2.659,0.15,0.143],[6.594,0.187,0.201],[5.081,0.512,0.608],[10.106,0.527,0.491],[10.271,0.588,0.537],[0.69,0.367,0.201],[0.161,0.093,0.093],[0.116,0.073,0.073],[0.197,0.045,0.044],[0.274,0.177,0.172],[0.096,0.018,0.022],[0.095,0.018,0.018],[0.101,0.029,0.028]],"source":"duckdb-parquet-partitioned/results/c7a.metal-48xl.json"}
-,{"system":"DuckDB (Parquet, partitioned)","date":"2025-07-12","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.054,0.001,0.002],[0.064,0.01,0.01],[0.155,0.057,0.058],[0.506,0.039,0.038],[1.398,0.189,0.188],[1.359,0.245,0.245],[0.058,0.02,0.021],[0.055,0.012,0.012],[0.831,0.249,0.247],[1.458,0.328,0.337],[0.628,0.062,0.06],[1.325,0.076,0.074],[1.645,0.246,0.245],[2.755,0.382,0.383],[1.02,0.273,0.271],[0.793,0.21,0.21],[2.831,0.508,0.511],[2.455,0.421,0.455],[4.719,0.885,0.869],[0.113,0.01,0.01],[10.558,0.503,0.503],[11.598,0.423,0.427],[20.755,0.83,0.824],[3.948,0.716,0.801],[0.152,0.067,0.066],[1.357,0.137,0.137],[0.312,0.048,0.048],[10.655,0.375,0.457],[8.938,5.156,5.137],[0.114,0.047,0.047],[2.562,0.288,0.293],[6.586,0.314,0.325],[5.177,0.943,0.923],[10.093,0.974,0.971],[10.064,0.991,1.01],[0.415,0.308,0.321],[0.127,0.069,0.066],[0.096,0.057,0.055],[0.091,0.029,0.029],[0.252,0.134,0.135],[0.062,0.016,0.014],[0.063,0.014,0.013],[0.062,0.018,0.018]],"source":"duckdb-parquet-partitioned/results/c8g.4xlarge.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.067,0.015,0.014],[0.117,0.045,0.045],[0.226,0.094,0.093],[0.507,0.094,0.092],[1.375,0.611,0.612],[1.126,0.87,0.87],[0.159,0.09,0.087],[0.139,0.048,0.048],[1.044,0.798,0.802],[1.444,1.019,1.036],[0.628,0.203,0.201],[1.086,0.248,0.248],[1.487,0.872,0.853],[2.923,1.301,1.309],[1.244,0.958,0.954],[0.914,0.694,0.678],[3.003,1.702,1.716],[2.653,1.368,1.367],[5.537,3.085,3.074],[0.198,0.034,0.034],[10.67,1.706,1.69],[11.924,1.546,1.589],[21.699,3.312,3.338],[2.921,0.799,0.718],[0.335,0.204,0.196],[1.053,0.504,0.496],[0.324,0.179,0.183],[10.325,1.438,1.439],[18.488,18.066,18.057],[0.206,0.272,0.091],[2.342,0.959,0.967],[5.964,1.071,1.073],[6.136,3.53,3.506],[10.207,3.492,3.486],[10.211,3.623,3.586],[1.131,0.913,0.927],[0.235,0.131,0.122],[0.187,0.107,0.119],[0.185,0.082,0.079],[0.442,0.213,0.248],[0.149,0.038,0.037],[0.124,0.035,0.036],[0.132,0.048,0.05]],"source":"duckdb-parquet/results/c6a.2xlarge.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-09-16","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.080,0.017,0.014],[0.119,0.035,0.035],[0.176,0.063,0.063],[0.436,0.058,0.058],[1.092,0.286,0.289],[0.946,0.497,0.491],[0.119,0.051,0.047],[0.118,0.037,0.034],[0.797,0.408,0.403],[1.109,0.508,0.516],[0.511,0.119,0.118],[0.943,0.140,0.136],[1.281,0.483,0.496],[2.459,0.813,0.813],[0.964,0.545,0.540],[0.744,0.347,0.349],[2.440,0.939,0.942],[2.207,0.729,0.756],[4.571,1.738,1.772],[0.215,0.037,0.037],[9.918,0.896,0.906],[11.142,0.811,0.819],[20.084,1.688,1.676],[2.671,0.420,0.428],[0.257,0.138,0.138],[0.964,0.257,0.259],[0.228,0.117,0.117],[9.877,0.751,0.757],[9.282,8.933,8.840],[0.169,0.059,0.059],[2.293,0.520,0.522],[5.891,0.619,0.615],[5.307,1.820,1.871],[10.055,2.215,2.205],[10.076,2.240,2.258],[0.646,0.460,0.470],[0.246,0.128,0.128],[0.190,0.104,0.103],[0.191,0.072,0.071],[0.453,0.241,0.239],[0.155,0.040,0.040],[0.136,0.041,0.039],[0.145,0.049,0.055]],"source":"duckdb-parquet/results/c6a.4xlarge.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.065,0.014,0.014],[0.239,0.138,0.135],[0.729,0.318,0.319],[0.929,0.31,0.31],[4.025,3.38,3.461],[4.053,3.341,3.386],[0.405,0.305,0.305],[0.303,0.146,0.146],[4.773,4.121,4.182],[5.935,4.992,4.996],[1.436,0.644,0.654],[1.704,0.795,0.803],[3.975,3.288,3.318],[6.601,5.452,5.41],[4.638,3.804,3.813],[4.413,3.917,3.965],[8.816,7.806,7.82],[8.836,7.701,7.794],[22.513,23.161,23.051],[0.613,0.07,0.068],[9.529,6.61,6.709],[11.171,6.121,6.09],[20.115,16.26,15.881],[3.089,2.549,3.308],[0.928,0.612,0.617],[2.48,1.905,1.9],[0.917,0.594,0.595],[9.565,5.551,5.617],[70.656,69.468,69.427],[0.554,0.476,0.469],[5.287,3.74,3.793],[7.412,4.691,4.753],[33.846,33.859,34.281],[24.916,24.823,25.477],[26.007,26.096,26.706],[4.371,3.88,4.001],[0.262,0.128,0.19],[0.218,0.102,0.155],[0.186,0.093,0.119],[0.491,0.282,0.349],[0.156,0.038,0.04],[0.135,0.037,0.038],[0.132,0.05,0.048]],"source":"duckdb-parquet/results/c6a.large.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-09-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.073,0.013,0.013],[0.151,0.032,0.027],[0.136,0.033,0.040],[0.287,0.041,0.037],[0.884,0.154,0.185],[0.781,0.230,0.217],[0.115,0.050,0.033],[0.119,0.040,0.028],[0.572,0.143,0.135],[0.945,0.161,0.165],[0.361,0.066,0.058],[0.808,0.105,0.065],[1.061,0.216,0.208],[1.999,0.341,0.394],[0.817,0.251,0.215],[0.446,0.118,0.117],[2.002,0.242,0.245],[1.991,0.243,0.263],[3.766,0.401,0.393],[0.168,0.033,0.032],[9.652,0.213,0.215],[10.966,0.283,0.192],[19.854,0.440,0.305],[10.978,0.785,0.395],[2.094,0.107,0.105],[0.950,0.104,0.112],[2.424,0.105,0.084],[9.711,0.205,0.187],[8.417,1.579,1.511],[0.156,0.037,0.038],[2.036,0.239,0.170],[5.457,0.222,0.176],[4.230,0.543,0.493],[9.613,0.527,0.513],[9.597,0.523,0.480],[0.633,0.148,0.129],[0.243,0.126,0.124],[0.197,0.101,0.099],[0.216,0.068,0.074],[0.429,0.235,0.230],[0.196,0.039,0.036],[0.166,0.039,0.037],[0.178,0.049,0.045]],"source":"duckdb-parquet/results/c6a.metal.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.068,0.016,0.015],[0.171,0.077,0.076],[0.366,0.166,0.166],[0.502,0.163,0.161],[1.414,1.091,1.098],[1.999,1.614,1.61],[0.239,0.158,0.158],[0.191,0.082,0.08],[1.823,1.436,1.435],[2.344,1.814,1.841],[0.775,0.356,0.355],[0.915,0.434,0.433],[1.981,1.579,1.574],[3.331,2.438,2.453],[2.208,1.744,1.766],[1.559,1.197,1.208],[3.855,3.285,3.287],[3.226,2.594,2.587],[6.772,5.88,5.918],[0.347,0.046,0.043],[10.826,3.265,3.275],[12.523,2.989,2.986],[23.574,6.301,6.333],[3.114,1.836,1.214],[0.529,0.343,0.347],[1.232,0.95,0.95],[0.518,0.319,0.319],[10.506,2.742,2.804],[35.85,35.072,35.16],[0.322,0.288,0.181],[2.624,1.766,1.794],[6.099,1.97,1.994],[7.831,7.441,7.452],[10.506,7.961,7.474],[10.597,8.073,7.742],[1.969,1.658,1.674],[0.239,0.123,0.178],[0.192,0.102,0.114],[0.183,0.082,0.082],[0.448,0.23,0.292],[0.145,0.036,0.035],[0.12,0.04,0.036],[0.136,0.049,0.052]],"source":"duckdb-parquet/results/c6a.xlarge.json"}
-,{"system":"DuckDB (Parquet, single)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.062,0.012,0.012],[0.121,0.025,0.021],[0.129,0.027,0.024],[0.273,0.03,0.025],[1,0.168,0.142],[0.907,0.171,0.161],[0.097,0.024,0.02],[0.11,0.025,0.022],[0.592,0.195,0.179],[0.961,0.206,0.188],[0.348,0.083,0.066],[0.831,0.086,0.063],[1.208,0.174,0.174],[2.13,0.322,0.348],[0.806,0.182,0.192],[0.381,0.175,0.159],[2.175,0.567,0.439],[2.119,0.57,0.444],[3.748,0.427,0.498],[0.169,0.027,0.021],[9.685,0.24,0.234],[10.95,0.261,0.209],[19.775,0.832,0.347],[11.07,0.396,0.404],[2.069,0.108,0.09],[1.044,0.096,0.087],[2.555,0.074,0.066],[9.838,0.194,0.192],[8.599,1.831,1.625],[0.127,0.03,0.028],[2.051,0.171,0.152],[5.5,0.25,0.2],[4.099,0.599,0.634],[9.684,0.631,0.859],[9.75,0.684,0.715],[0.496,0.215,0.183],[0.229,0.114,0.114],[0.171,0.095,0.095],[0.176,0.065,0.063],[0.368,0.209,0.209],[0.142,0.034,0.032],[0.127,0.033,0.03],[0.115,0.044,0.042]],"source":"duckdb-parquet/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.144,0.002,0.001],[0.078,0.022,0.023],[0.143,0.023,0.023],[0.648,0.027,0.025],[1.299,0.089,0.088],[1.559,0.171,0.163],[0.084,0.02,0.02],[0.112,0.027,0.025],[1.106,0.168,0.116],[1.728,0.138,0.142],[1.083,0.05,0.044],[1.332,0.055,0.05],[1.662,0.188,0.15],[2.72,0.23,0.207],[1.364,0.207,0.2],[0.985,0.104,0.098],[2.843,0.41,0.278],[2.429,0.288,0.382],[4.339,0.364,0.349],[0.177,0.024,0.024],[10.225,0.211,0.196],[11.663,0.26,0.194],[20.219,0.884,0.393],[5.853,1.424,0.29],[0.434,0.369,0.078],[1.618,0.078,0.067],[0.587,0.43,0.058],[10.327,0.173,0.167],[9.166,1.583,1.667],[0.134,0.033,0.03],[2.487,0.136,0.132],[6.39,0.174,0.159],[4.968,0.55,0.469],[9.724,0.536,0.509],[9.749,0.738,0.506],[0.422,0.132,0.132],[0.198,0.097,0.1],[0.138,0.078,0.078],[0.139,0.05,0.051],[0.35,0.19,0.187],[0.112,0.025,0.022],[0.116,0.029,0.028],[0.114,0.033,0.032]],"source":"duckdb-parquet-partitioned/results/c6a.metal.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.109,0.002,0.001],[0.165,0.067,0.067],[0.406,0.193,0.192],[0.778,0.164,0.163],[1.924,0.921,0.929],[2.016,1.557,1.563],[0.278,0.157,0.157],[0.225,0.069,0.07],[1.738,1.304,1.318],[2.34,1.702,1.747],[0.958,0.351,0.347],[1.545,0.412,0.411],[2.234,1.533,1.543],[4.191,2.353,2.381],[2.305,1.713,1.725],[1.474,1.056,1.069],[4.38,3.182,3.154],[3.731,2.477,2.528],[8.256,6.112,6.179],[0.372,0.035,0.034],[11.441,3.226,3.214],[11.211,2.961,2.968],[19.504,6.391,6.48],[4.116,1.773,1.755],[0.543,0.329,0.31],[1.332,0.961,0.955],[0.47,0.253,0.254],[9.556,2.727,2.792],[37.293,36.48,36.577],[0.407,0.295,0.385],[2.76,1.703,1.72],[6.361,1.922,1.989],[8.173,7.478,7.658],[10.694,8.93,8.485],[10.625,8.928,8.83],[2.326,2.013,2.047],[0.189,0.116,0.119],[0.151,0.085,0.099],[0.146,0.095,0.138],[0.378,0.249,0.209],[0.132,0.021,0.021],[0.125,0.023,0.022],[0.131,0.039,0.035]],"source":"duckdb-parquet-partitioned/results/c6a.xlarge.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.172,0.002,0.001],[0.11,0.021,0.02],[0.165,0.025,0.024],[0.573,0.024,0.023],[1.276,0.078,0.071],[1.623,0.151,0.148],[0.102,0.025,0.02],[0.103,0.024,0.025],[1.023,0.098,0.087],[1.723,0.109,0.103],[1.098,0.045,0.038],[1.308,0.05,0.041],[1.61,0.169,0.159],[2.687,0.197,0.174],[1.282,0.167,0.16],[0.984,0.086,0.078],[2.75,0.183,0.173],[2.532,0.192,0.27],[4.291,0.314,0.28],[0.174,0.023,0.017],[10.182,0.197,0.182],[11.63,0.218,0.145],[20.461,0.768,0.4],[5.024,1.17,0.277],[0.685,0.078,0.073],[1.578,0.073,0.066],[0.622,0.318,0.055],[10.282,0.172,0.156],[9.102,1.152,1.15],[0.138,0.028,0.027],[2.415,0.132,0.114],[6.321,0.168,0.133],[4.872,0.415,0.399],[9.723,0.601,0.358],[9.815,0.436,0.395],[0.385,0.111,0.094],[0.24,0.093,0.096],[0.125,0.075,0.074],[0.189,0.047,0.048],[0.315,0.183,0.179],[0.454,0.024,0.023],[0.101,0.026,0.027],[0.105,0.029,0.029]],"source":"duckdb-parquet-partitioned/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.045,0.002,0.001],[0.094,0.013,0.013],[0.216,0.052,0.053],[0.833,0.035,0.035],[1.728,0.155,0.154],[1.891,0.264,0.262],[0.107,0.024,0.023],[0.053,0.014,0.014],[1.504,0.224,0.221],[2.231,0.295,0.303],[1.345,0.064,0.063],[1.735,0.077,0.075],[1.915,0.272,0.267],[3.232,0.433,0.43],[1.426,0.299,0.298],[1.188,0.19,0.186],[3.394,0.522,0.531],[2.782,0.42,0.443],[5.145,0.905,0.893],[0.848,0.011,0.011],[11.118,0.637,0.637],[11.932,0.58,0.578],[22.531,1.103,1.097],[4.399,0.802,0.906],[0.406,0.07,0.068],[1.579,0.145,0.144],[0.6,0.05,0.051],[11,0.505,0.51],[9.953,4.798,4.772],[0.109,0.059,0.061],[2.894,0.291,0.296],[7.573,0.32,0.326],[5.615,0.785,0.792],[10.377,1.132,1.141],[10.382,1.141,1.163],[0.418,0.291,0.298],[0.151,0.086,0.086],[0.104,0.068,0.068],[0.112,0.047,0.044],[0.319,0.167,0.165],[0.065,0.018,0.017],[0.061,0.016,0.015],[0.065,0.025,0.026]],"source":"duckdb-parquet-partitioned/results/c8g.4xlarge.json"}
+,{"system":"DuckDB (Parquet, partitioned)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14737666736,"result":[[0.096,0.001,0.001],[0.069,0.017,0.012],[0.114,0.018,0.018],[0.645,0.018,0.017],[1.292,0.092,0.055],[1.582,0.14,0.133],[0.073,0.013,0.012],[0.081,0.015,0.017],[1.153,0.076,0.07],[1.709,0.089,0.085],[1.133,0.036,0.034],[1.313,0.038,0.036],[1.627,0.137,0.132],[2.707,0.263,0.256],[1.232,0.141,0.145],[0.991,0.08,0.063],[2.798,0.235,0.159],[2.545,0.255,0.21],[4.315,0.231,0.234],[0.384,0.015,0.016],[10.039,0.179,0.181],[11.694,0.199,0.143],[20.309,0.654,0.367],[10.155,1.002,0.307],[0.448,0.394,0.067],[1.617,0.06,0.06],[0.574,0.598,0.046],[10.344,0.146,0.142],[8.758,0.982,0.939],[0.126,0.023,0.023],[2.442,0.136,0.099],[6.359,0.144,0.121],[4.964,0.341,0.335],[9.738,0.505,0.361],[9.718,0.472,0.355],[0.312,0.077,0.086],[0.184,0.092,0.09],[0.121,0.069,0.071],[0.138,0.048,0.048],[0.319,0.173,0.177],[0.091,0.017,0.019],[0.096,0.02,0.017],[0.096,0.027,0.027]],"source":"duckdb-parquet-partitioned/results/c8g.metal-48xl.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.098,0.014,0.014],[0.166,0.05,0.047],[0.272,0.094,0.094],[0.426,0.094,0.093],[1.114,0.471,0.477],[1.102,0.851,0.845],[0.188,0.08,0.079],[0.13,0.05,0.049],[0.862,0.649,0.654],[1.173,0.845,0.876],[0.514,0.2,0.195],[0.676,0.24,0.235],[1.105,0.847,0.844],[2.548,1.266,1.266],[1.231,0.93,0.94],[0.886,0.543,0.545],[2.533,1.574,1.598],[2.218,1.266,1.274],[4.855,2.988,2.998],[0.225,0.035,0.035],[10.92,1.726,1.713],[11.146,1.564,1.607],[20.272,3.245,3.335],[2.673,0.897,0.708],[0.35,0.211,0.207],[0.828,0.515,0.523],[0.336,0.188,0.183],[9.65,1.445,1.466],[20.386,19.153,19.061],[0.216,0.088,0.089],[2.334,0.92,0.943],[5.953,1.046,1.068],[5.945,3.1,3.322],[10.198,3.391,3.354],[10.252,3.525,3.556],[0.99,0.767,0.78],[0.248,0.126,0.179],[0.195,0.108,0.124],[0.194,0.075,0.081],[0.457,0.283,0.369],[0.156,0.038,0.039],[0.132,0.038,0.037],[0.141,0.05,0.05]],"source":"duckdb-parquet/results/c6a.2xlarge.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.172,0.013,0.014],[0.305,0.034,0.031],[0.431,0.057,0.057],[0.951,0.06,0.06],[0.92,0.279,0.282],[1.078,0.508,0.517],[0.273,0.048,0.046],[0.117,0.036,0.033],[0.812,0.394,0.395],[1.144,0.509,0.511],[0.577,0.118,0.115],[0.996,0.139,0.134],[1.377,0.505,0.497],[2.563,0.833,0.822],[0.994,0.553,0.552],[0.835,0.341,0.34],[2.525,0.948,0.96],[2.309,0.741,0.755],[4.78,1.729,1.751],[0.269,0.036,0.035],[10.471,0.888,0.898],[11.501,0.822,0.828],[20.826,1.723,1.73],[4.335,0.812,0.849],[0.284,0.145,0.142],[1.006,0.272,0.276],[0.262,0.12,0.125],[10.265,0.763,0.754],[11.066,9.722,9.765],[0.157,0.275,0.123],[2.394,0.535,0.544],[6.143,0.625,0.636],[5.488,1.893,1.837],[10.331,2.189,2.177],[10.404,2.262,2.286],[0.621,0.462,0.47],[0.254,0.121,0.126],[0.181,0.105,0.117],[0.202,0.075,0.081],[0.417,0.254,0.246],[0.502,0.041,0.04],[0.148,0.037,0.037],[0.127,0.049,0.049]],"source":"duckdb-parquet/results/c6a.4xlarge.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":1,"data_size":14779976446,"result":[[0.073,0.019,0.019],[1.152,0.14,0.139],[2.022,0.308,0.309],[4.464,0.299,0.301],[3.864,3.317,3.352],[6.834,3.571,3.609],[1.487,0.263,0.262],[0.274,0.149,0.147],[4.822,3.889,3.958],[5.522,4.599,4.732],[2.142,0.583,0.595],[1.498,0.732,0.744],[4.131,3.5,3.445],[6.608,5.535,5.512],[4.659,3.849,3.805],[4.322,3.659,3.764],[8.953,7.829,7.847],[7.814,6.634,6.757],[372.44,998.788,3495.008],[0.601,0.066,0.063],[11.262,6.569,6.57],[11.151,6.002,5.973],[25.86,16.123,16.277],[3.035,2.617,2.776],[1.005,0.664,0.626],[2.504,1.958,1.952],[0.887,0.606,0.602],[9.568,5.563,5.609],[75.694,73.635,73.479],[0.572,0.475,0.454],[5.483,3.923,3.954],[8.178,4.92,5.007],[29.914,30.022,30.127],[24.118,24.759,25.041],[25.858,27.461,27.197],[4.583,4.069,4.108],[0.256,0.15,0.196],[0.202,0.103,0.133],[0.193,0.097,0.155],[0.49,0.446,0.371],[0.167,0.041,0.04],[0.143,0.04,0.041],[0.144,0.052,0.051]],"source":"duckdb-parquet/results/c6a.large.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.1,0.013,0.012],[0.141,0.029,0.026],[0.168,0.035,0.033],[0.41,0.035,0.032],[0.842,0.109,0.172],[0.899,0.203,0.236],[0.136,0.027,0.03],[0.124,0.03,0.029],[0.571,0.128,0.132],[1.119,0.262,0.149],[0.371,0.064,0.056],[0.83,0.068,0.059],[1.169,0.203,0.199],[2.113,0.398,0.429],[0.809,0.234,0.199],[0.56,0.121,0.111],[2.09,0.278,0.258],[1.993,0.255,0.258],[3.779,0.403,0.383],[0.405,0.032,0.03],[9.408,0.224,0.206],[10.963,0.22,0.184],[19.904,0.578,0.38],[12.482,0.407,0.413],[2.086,0.149,0.106],[0.918,0.098,0.101],[1.677,0.133,0.085],[9.895,0.276,0.179],[8.953,1.694,1.539],[0.144,0.037,0.039],[2.039,0.177,0.2],[5.488,0.215,0.178],[4.213,0.503,0.491],[9.697,0.535,0.517],[9.671,0.721,0.57],[0.61,0.135,0.133],[0.254,0.122,0.123],[0.191,0.109,0.109],[0.192,0.066,0.074],[0.397,0.233,0.227],[0.362,0.039,0.038],[0.161,0.038,0.038],[0.174,0.046,0.055]],"source":"duckdb-parquet/results/c6a.metal.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.066,0.016,0.016],[0.158,0.078,0.077],[0.35,0.163,0.164],[0.505,0.162,0.16],[1.182,0.86,0.87],[1.962,1.566,1.571],[0.23,0.14,0.14],[0.203,0.083,0.082],[1.548,1.166,1.176],[2.097,1.533,1.557],[0.77,0.346,0.345],[0.897,0.42,0.416],[1.94,1.534,1.547],[2.951,2.284,2.319],[2.203,1.71,1.704],[1.347,0.988,1],[3.573,2.934,2.941],[3.035,2.339,2.31],[6.63,5.772,5.816],[0.351,0.046,0.044],[9.736,3.311,3.325],[11.145,3.055,3.054],[20.026,6.398,6.391],[2.66,1.316,1.274],[0.588,0.356,0.36],[1.302,0.993,0.996],[0.55,0.329,0.321],[9.552,2.785,2.85],[38.054,37.25,37.411],[0.329,0.173,0.785],[2.6,1.725,1.752],[6.094,1.927,1.991],[7.626,7.021,7.263],[10.518,8.133,7.591],[10.488,8.776,8.563],[1.765,1.44,1.499],[0.256,0.156,0.182],[0.194,0.11,0.168],[0.192,0.077,0.11],[0.489,0.272,0.251],[0.158,0.043,0.037],[0.133,0.039,0.039],[0.14,0.062,0.055]],"source":"duckdb-parquet/results/c6a.xlarge.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.126,0.015,0.012],[0.279,0.034,0.027],[0.317,0.031,0.028],[0.673,0.035,0.029],[0.602,0.223,0.088],[0.919,0.179,0.174],[0.159,0.03,0.024],[0.115,0.032,0.027],[0.548,0.106,0.099],[1.145,0.133,0.115],[0.486,0.065,0.053],[0.868,0.077,0.065],[1.174,0.177,0.161],[1.98,0.305,0.208],[0.808,0.183,0.176],[0.573,0.092,0.087],[2.171,0.249,0.206],[1.991,0.213,0.201],[3.717,0.324,0.3],[0.175,0.033,0.026],[10.873,0.213,0.21],[10.941,0.229,0.16],[20.448,0.342,0.27],[11.374,0.386,0.381],[2.073,0.112,0.091],[1.021,0.087,0.089],[2.508,0.079,0.07],[9.801,0.179,0.168],[8.524,1.169,1.092],[0.139,0.039,0.034],[2.022,0.181,0.136],[5.442,0.194,0.162],[4.148,0.411,0.445],[9.56,0.427,0.39],[9.596,0.444,0.415],[0.572,0.097,0.096],[0.255,0.118,0.119],[0.168,0.098,0.099],[0.199,0.072,0.071],[0.361,0.228,0.227],[0.332,0.038,0.035],[0.149,0.038,0.036],[0.136,0.046,0.043]],"source":"duckdb-parquet/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.055,0.014,0.014],[0.167,0.024,0.025],[0.207,0.041,0.04],[0.604,0.038,0.039],[1.386,0.159,0.157],[1.624,0.272,0.271],[0.141,0.032,0.031],[0.09,0.025,0.026],[0.85,0.219,0.218],[1.714,0.29,0.293],[0.899,0.074,0.072],[1.428,0.088,0.086],[1.641,0.279,0.276],[2.744,0.425,0.427],[1.062,0.303,0.305],[0.875,0.186,0.186],[2.969,0.494,0.499],[2.414,0.42,0.463],[4.611,0.879,0.87],[0.214,0.021,0.021],[11.049,0.666,0.665],[11.736,0.59,0.588],[21.691,1.098,1.116],[3.434,1.37,0.925],[0.208,0.093,0.091],[1.419,0.157,0.156],[0.593,0.073,0.072],[10.787,0.526,0.528],[9.313,4.915,4.898],[0.311,0.6,0.458],[2.242,0.307,0.303],[5.776,0.329,0.331],[4.535,0.884,0.807],[9.709,1.167,1.138],[9.715,1.148,1.194],[0.393,0.243,0.251],[0.207,0.108,0.171],[0.16,0.087,0.086],[0.169,0.064,0.062],[0.409,0.211,0.203],[0.129,0.031,0.031],[0.109,0.03,0.028],[0.114,0.039,0.039]],"source":"duckdb-parquet/results/c8g.4xlarge.json"}
+,{"system":"DuckDB (Parquet, single)","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.061,0.012,0.013],[0.126,0.021,0.019],[0.128,0.022,0.022],[0.523,0.029,0.025],[1.237,0.134,0.071],[1.404,0.154,0.164],[0.113,0.02,0.02],[0.116,0.023,0.019],[0.856,0.087,0.085],[1.562,0.101,0.1],[0.988,0.048,0.042],[1.208,0.05,0.047],[1.566,0.166,0.163],[2.552,0.277,0.282],[0.982,0.165,0.157],[0.785,0.08,0.074],[2.639,0.187,0.162],[2.3,0.188,0.171],[4.052,0.251,0.228],[0.186,0.025,0.024],[9.667,0.186,0.182],[10.952,0.207,0.174],[19.935,0.502,0.302],[10.773,0.371,0.659],[2.064,0.104,0.08],[1.05,0.073,0.073],[2.556,0.077,0.064],[9.815,0.161,0.152],[8.225,0.901,0.875],[0.213,0.027,0.027],[2.037,0.203,0.133],[5.448,0.203,0.137],[4.218,0.393,0.384],[9.609,0.41,0.34],[9.617,0.513,0.355],[0.408,0.082,0.08],[0.231,0.114,0.113],[0.166,0.092,0.09],[0.181,0.068,0.078],[0.374,0.215,0.21],[0.149,0.033,0.032],[0.13,0.031,0.03],[0.129,0.041,0.041]],"source":"duckdb-parquet/results/c8g.metal-48xl.json"}
,{"system":"DuckDB (Parquet, single)","date":"2025-08-31","machine":"t3a.small","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded","stateless"],"load_time":0,"data_size":14779976446,"result":[[0.139,0.037,0.039],[0.427,0.231,0.226],[0.987,0.528,0.53],[1.225,0.513,0.498],[6.487,5.907,6.111],[6.262,5.438,5.44],[0.63,0.468,0.47],[0.46,0.244,0.244],[7.624,7.038,7.141],[9.439,8.394,8.587],[2.048,1.124,1.134],[2.43,1.406,1.397],[6.019,5.229,5.317],[10.271,10.135,10.08],[7.041,6.052,6.103],[7.042,6.258,6.388],[null,null,null],[null,null,null],[null,null,null],[15.004,0.226,0.227],[125.953,124.796,124.7],[145.013,143.85,143.498],[251.563,252.499,249.288],[42.812,4.392,3.434],[1.308,0.976,0.975],[19.716,2.849,2.838],[4.262,0.927,0.917],[125.628,125.007,124.948],[116.299,115.145,115.69],[0.788,1.016,0.504],[13.967,6.14,6.156],[69.305,78.763,78.268],[684.6,1102.323,1847.261],[null,null,null],[null,null,null],[14.641,6.8,7.052],[0.398,0.239,0.25],[0.34,0.2,0.277],[0.277,0.144,0.179],[0.698,0.501,0.674],[0.215,0.077,0.072],[0.189,0.073,0.081],[0.207,0.097,0.093]],"source":"duckdb-parquet/results/t3a.small.json"}
,{"system":"DuckDB (Vortex, partitioned)","date":"2025-08-06","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"","tags":["Rust","column-oriented","embedded","stateless"],"load_time":742.26,"data_size":15961049404,"result":[[0.184,0.013,0.003],[0.523,0.014,0.014],[1.610,0.035,0.035],[3.435,0.049,0.052],[3.466,0.329,0.332],[4.172,0.297,0.292],[0.181,0.022,0.020],[0.567,0.019,0.018],[4.334,0.415,0.405],[4.319,0.561,0.558],[2.784,0.097,0.091],[3.485,0.124,0.107],[4.721,0.307,0.316],[7.135,0.672,0.675],[4.478,0.343,0.342],[2.783,0.392,0.387],[7.061,0.852,0.847],[6.856,0.740,0.628],[9.200,1.517,1.505],[1.971,0.038,0.031],[33.849,0.556,0.530],[36.486,0.679,0.636],[40.129,1.065,1.072],[7.566,0.392,0.382],[1.880,0.122,0.062],[4.896,0.096,0.098],[1.791,0.126,0.031],[34.787,0.863,0.790],[28.059,9.317,9.314],[0.717,0.033,0.033],[7.835,0.279,0.317],[13.900,0.420,0.403],[10.751,1.919,1.892],[34.222,2.047,1.980],[34.208,2.288,2.131],[1.861,0.511,0.506],[0.258,0.025,0.024],[0.840,0.012,0.021],[1.098,0.024,0.018],[1.265,0.063,0.053],[0.815,0.022,0.008],[0.889,0.010,0.010],[0.833,0.032,0.012]],"source":"duckdb-vortex-partitioned/results/c6a.4xlarge.json"}
,{"system":"DuckDB (Vortex, single)","date":"2025-05-21","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"","tags":["Rust","column-oriented","embedded","stateless"],"load_time":0,"data_size":17138413352,"result":[[0.129,0.009,0.009],[0.316,0.058,0.058],[1.203,0.150,0.150],[2.647,0.146,0.153],[2.763,0.414,0.412],[2.518,0.584,0.585],[0.234,0.107,0.110],[0.338,0.063,0.063],[4.047,0.595,0.572],[5.539,0.817,0.819],[2.342,0.326,0.321],[2.478,0.341,0.338],[2.596,0.621,0.619],[5.883,0.965,0.960],[2.908,0.649,0.650],[2.366,0.483,0.487],[5.805,1.287,1.262],[5.806,1.076,1.039],[8.363,2.188,2.193],[1.991,0.580,0.572],[26.778,1.731,1.733],[29.899,1.896,1.896],[39.083,2.986,2.973],[107.607,71.144,52.572],[4.731,0.453,0.459],[2.441,0.375,0.370],[4.725,0.470,0.467],[26.806,1.735,1.786],[20.778,10.216,10.217],[0.515,0.106,0.111],[6.083,0.575,0.581],[12.189,0.759,0.738],[10.020,2.208,2.159],[27.433,2.884,2.905],[27.539,3.811,3.769],[1.158,0.766,0.743],[1.918,1.819,1.777],[2.442,1.119,1.116],[1.817,1.669,1.668],[3.125,2.950,2.955],[0.578,0.445,0.448],[0.518,0.388,0.390],[0.366,0.235,0.233]],"source":"duckdb-vortex/results/c6a.4xlarge.json"}
-,{"system":"DuckDB","date":"2025-08-31","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":396,"data_size":23675809792,"result":[[0.028,0.001,0],[0.184,0.006,0.005],[0.955,0.036,0.035],[1.145,0.059,0.058],[1.122,0.569,0.567],[1.806,0.714,0.705],[0.144,0.011,0.009],[0.193,0.007,0.008],[1.815,0.713,0.72],[2.849,0.989,1.005],[1.703,0.263,0.261],[1.896,0.278,0.277],[1.865,0.632,0.636],[3.531,1.029,1.034],[2.169,0.673,0.669],[0.957,0.628,0.631],[3.496,1.436,1.431],[3.129,1.053,1.093],[6.579,2.613,2.612],[0.212,0.006,0.005],[19.028,1.132,1.13],[21.186,1.023,1.053],[35.43,1.749,1.741],[2.645,0.58,0.205],[0.239,0.042,0.041],[0.164,0.037,0.034],[0.231,0.042,0.041],[19.307,0.782,0.809],[19.257,17.376,17.422],[0.311,0.043,0.043],[4.898,0.586,0.599],[8.244,0.692,0.721],[7.185,3.136,3.233],[19.274,3.148,3.121],[19.177,3.176,3.158],[1.066,0.792,0.857],[0.142,0.029,0.043],[0.094,0.015,0.019],[0.101,0.016,0.014],[0.181,0.107,0.153],[0.105,0.004,0.004],[0.085,0.006,0.005],[0.086,0.01,0.01]],"source":"duckdb/results/c6a.2xlarge.json"}
-,{"system":"DuckDB","date":"2025-09-16","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":110.78,"data_size":20549742592,"result":[[0.026,0.000,0.000],[0.170,0.003,0.003],[1.021,0.018,0.019],[1.130,0.032,0.031],[1.150,0.243,0.246],[1.213,0.282,0.275],[0.107,0.005,0.004],[0.152,0.004,0.004],[1.851,0.335,0.339],[2.747,0.495,0.500],[1.329,0.066,0.065],[2.160,0.075,0.073],[1.532,0.306,0.310],[2.671,0.622,0.612],[1.749,0.351,0.351],[0.530,0.300,0.307],[2.620,0.737,0.748],[2.386,0.503,0.503],[5.381,1.386,1.401],[0.143,0.004,0.003],[11.305,0.477,0.474],[12.437,0.493,0.482],[14.806,2.351,1.428],[1.005,0.093,0.094],[0.155,0.020,0.020],[1.642,0.066,0.066],[0.253,0.017,0.016],[11.837,0.387,0.389],[8.817,6.559,6.562],[0.192,0.024,0.023],[4.869,0.260,0.256],[7.168,0.330,0.330],[6.132,1.655,1.694],[11.221,1.629,1.643],[11.255,1.796,1.831],[0.607,0.393,0.393],[0.110,0.029,0.026],[0.077,0.007,0.007],[0.097,0.011,0.012],[0.175,0.064,0.058],[0.097,0.006,0.004],[0.079,0.006,0.006],[0.081,0.012,0.010]],"source":"duckdb/results/c6a.4xlarge.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":152,"data_size":20550266880,"result":[[0.026,0,0],[0.192,0.006,0.004],[1.079,0.034,0.034],[1.058,0.062,0.062],[1.063,0.426,0.429],[1.08,0.401,0.414],[0.147,0.009,0.008],[0.261,0.008,0.007],[1.659,0.563,0.575],[2.786,0.822,0.85],[1.36,0.128,0.126],[2.007,0.143,0.141],[1.374,0.445,0.459],[2.759,0.873,0.883],[1.788,0.522,0.525],[0.926,0.494,0.504],[2.696,1.168,1.178],[2.379,0.804,0.837],[5.647,2.25,2.277],[0.222,0.006,0.005],[11.541,0.925,0.924],[12.729,0.985,0.945],[17.398,2.211,1.456],[1.047,0.578,0.654],[0.236,0.043,0.032],[1.082,0.128,0.125],[0.228,0.028,0.029],[11.928,0.757,0.767],[15.278,14.057,14.018],[0.336,0.043,0.042],[4.49,0.426,0.446],[7.371,0.541,0.555],[6.863,2.813,2.835],[11.597,2.521,2.435],[11.568,2.763,2.792],[0.975,0.661,0.684],[0.118,0.027,0.026],[0.086,0.007,0.009],[0.099,0.015,0.012],[0.19,0.074,0.062],[0.102,0.005,0.004],[0.085,0.006,0.005],[0.084,0.01,0.01]],"source":"duckdb/results/c6a.2xlarge.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":111,"data_size":20551053312,"result":[[0.027,0.001,0],[0.117,0.003,0.003],[1.066,0.018,0.018],[1.139,0.034,0.032],[1.18,0.245,0.246],[1.17,0.28,0.28],[0.096,0.005,0.004],[0.122,0.005,0.004],[1.831,0.339,0.339],[2.741,0.506,0.562],[1.331,0.069,0.067],[2.082,0.077,0.076],[1.511,0.317,0.314],[2.68,0.618,0.624],[1.744,0.354,0.354],[0.664,0.303,0.303],[2.616,0.742,0.752],[2.389,0.505,0.521],[5.378,1.408,1.419],[0.143,0.004,0.003],[11.242,0.486,0.476],[12.444,0.497,0.507],[16.055,1.949,0.83],[0.992,0.164,0.103],[0.143,0.021,0.02],[1.265,0.068,0.067],[0.285,0.016,0.016],[11.83,0.397,0.417],[8.826,7.245,7.259],[0.177,0.025,0.024],[4.38,0.262,0.319],[7.142,0.332,0.357],[6.139,1.677,1.702],[11.234,1.658,1.657],[11.257,1.839,1.828],[0.582,0.397,0.46],[0.096,0.028,0.058],[0.07,0.009,0.007],[0.085,0.09,0.014],[0.153,0.063,0.055],[0.087,0.006,0.005],[0.081,0.006,0.006],[0.086,0.01,0.011]],"source":"duckdb/results/c6a.4xlarge.json"}
,{"system":"DuckDB","date":"2025-08-31","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":846,"data_size":23642517504,"result":[[0.025,0,0.001],[0.798,0.017,0.017],[1.935,0.137,0.135],[1.759,0.235,0.227],[4.46,3.245,3.269],[4.987,2.766,2.7],[0.552,0.033,0.032],[0.889,0.027,0.025],[5.371,3.615,3.669],[7.771,4.6,4.641],[3.393,0.955,0.947],[3.346,1.011,1.006],[4.662,2.351,2.499],[7.685,4.157,4.284],[5.21,2.716,2.751],[4.809,3.512,3.419],[9.896,6.67,6.887],[9.727,6.514,6.534],[23.468,24.11,23.954],[0.922,0.02,0.019],[18.332,19.183,19.188],[21.164,21.787,21.809],[35.007,35.886,35.776],[2.722,1.237,1.086],[0.634,0.124,0.12],[0.321,0.068,0.059],[0.725,0.131,0.131],[18.644,19.484,19.51],[null,null,null],[1.067,0.413,0.382],[7.234,2.306,2.349],[10.779,3.221,3.549],[34.872,35.819,35.573],[32.813,32.819,33.173],[33.084,33.194,33.018],[4.363,3.338,3.399],[0.284,0.085,0.131],[0.171,0.035,0.083],[0.207,0.11,0.14],[0.491,0.292,0.272],[0.19,0.009,0.007],[0.164,0.008,0.008],[0.14,0.018,0.018]],"source":"duckdb/results/c6a.large.json"}
-,{"system":"DuckDB","date":"2025-09-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":102.80,"data_size":20557869056,"result":[[0.031,0.000,0.001],[0.122,0.003,0.006],[2.167,0.007,0.004],[1.696,0.007,0.006],[1.755,0.083,0.082],[2.180,0.105,0.097],[0.081,0.003,0.002],[0.586,0.005,0.005],[2.865,0.107,0.104],[4.453,0.127,0.127],[2.397,0.032,0.031],[3.208,0.034,0.031],[2.333,0.092,0.084],[3.972,0.165,0.151],[2.935,0.133,0.114],[1.107,0.091,0.090],[4.125,0.173,0.163],[3.955,0.179,0.369],[7.451,0.328,0.317],[0.353,0.007,0.006],[16.283,0.272,0.086],[18.131,0.166,0.078],[16.737,0.265,0.136],[2.760,0.692,0.189],[0.545,0.036,0.017],[2.577,0.026,0.024],[1.159,0.049,0.009],[16.720,0.185,0.070],[12.607,1.049,1.055],[0.420,0.011,0.011],[7.473,0.081,0.075],[10.388,0.098,0.091],[8.060,0.452,0.453],[15.800,0.402,0.317],[15.934,0.437,0.372],[0.734,0.104,0.098],[0.094,0.025,0.025],[0.061,0.008,0.008],[0.079,0.015,0.012],[0.161,0.053,0.050],[0.091,0.007,0.006],[0.071,0.008,0.007],[0.072,0.012,0.011]],"source":"duckdb/results/c6a.metal.json"}
-,{"system":"DuckDB","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":491,"data_size":23653789696,"result":[[0.026,0,0],[0.39,0.009,0.009],[0.875,0.069,0.069],[0.836,0.114,0.114],[1.628,1.073,1.062],[2.399,1.327,1.321],[0.259,0.017,0.017],[0.397,0.015,0.013],[2.104,1.338,1.331],[3.195,1.823,1.849],[1.677,0.508,0.506],[1.812,0.537,0.535],[2.275,1.166,1.188],[3.8,1.904,1.919],[2.438,1.243,1.249],[1.767,1.146,1.164],[4.411,2.848,2.89],[3.681,2.063,2.041],[7.648,5.278,5.283],[0.429,0.01,0.01],[18.426,2.294,2.294],[20.724,2.219,2.187],[34.649,26.798,19.916],[2.141,0.718,0.637],[0.396,0.069,0.072],[0.19,0.05,0.035],[0.37,0.075,0.075],[18.476,1.607,1.63],[37.462,34.181,34.319],[0.586,0.094,0.095],[4.863,1.081,1.113],[8.249,1.287,1.317],[8.808,7.918,8.171],[19.254,17.123,17.384],[19.334,17.158,17.009],[1.962,1.51,1.535],[0.192,0.053,0.093],[0.11,0.024,0.072],[0.147,0.023,0.03],[0.28,0.226,0.194],[0.124,0.006,0.006],[0.099,0.007,0.006],[0.101,0.016,0.015]],"source":"duckdb/results/c6a.xlarge.json"}
-,{"system":"DuckDB","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":145,"data_size":23673188352,"result":[[0.029,0,0],[0.103,0.01,0.011],[2.092,0.024,0.023],[1.665,0.026,0.025],[1.745,0.152,0.151],[2.847,0.162,0.161],[0.071,0.023,0.026],[0.536,0.01,0.01],[2.807,0.185,0.178],[4.247,0.22,0.209],[2.684,0.095,0.088],[3.285,0.095,0.09],[3.083,0.149,0.148],[4.811,0.271,0.256],[3.124,0.152,0.153],[1.125,0.366,0.173],[4.63,0.363,0.352],[4.63,0.378,0.372],[8.025,0.451,0.46],[0.323,0.004,0.004],[23.388,0.144,0.116],[25.89,0.192,0.092],[40.956,0.367,0.135],[4.558,0.042,0.04],[1.105,0.025,0.014],[1.704,0.218,0.054],[1.312,0.033,0.009],[23.722,0.272,0.076],[17.495,1.06,1.015],[0.358,0.037,0.03],[7.503,0.127,0.131],[10.694,0.278,0.163],[7.461,0.547,0.587],[22.746,0.463,0.469],[22.974,0.691,0.639],[0.721,0.345,0.304],[0.101,0.023,0.022],[0.074,0.012,0.011],[0.083,0.01,0.01],[0.14,0.049,0.044],[0.072,0.004,0.005],[0.066,0.006,0.006],[0.066,0.007,0.007]],"source":"duckdb/results/c7a.metal-48xl.json"}
-,{"system":"DuckDB","date":"2025-08-30","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":406,"data_size":23648284672,"result":[[0.02,0.001,0],[0.099,0.004,0.004],[1.086,0.013,0.013],[1.123,0.02,0.019],[1.134,0.168,0.167],[1.956,0.208,0.206],[0.085,0.011,0.011],[0.177,0.005,0.005],[1.925,0.211,0.21],[2.768,0.294,0.299],[1.583,0.082,0.081],[2.222,0.087,0.086],[2.112,0.192,0.192],[3.207,0.309,0.308],[1.983,0.203,0.203],[0.578,0.19,0.187],[3.286,0.421,0.43],[2.99,0.322,0.341],[5.636,0.723,0.707],[0.121,0.002,0.002],[18.68,0.4,0.4],[20.544,0.344,0.338],[34.406,0.531,0.554],[2.05,0.601,0.079],[0.116,0.021,0.015],[0.229,0.02,0.018],[0.608,0.016,0.014],[19.129,0.238,0.257],[13.31,4.758,4.765],[0.138,0.018,0.02],[4.621,0.186,0.193],[7.975,0.212,0.213],[5.582,0.794,0.811],[18.152,0.84,0.807],[18.146,0.823,0.849],[0.35,0.224,0.231],[0.091,0.016,0.017],[0.073,0.01,0.009],[0.083,0.008,0.008],[0.145,0.033,0.032],[0.075,0.003,0.002],[0.062,0.004,0.003],[0.063,0.005,0.005]],"source":"duckdb/results/c8g.4xlarge.json"}
-,{"system":"DuckDB","date":"2025-08-30","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":158,"data_size":23667683328,"result":[[0.027,0,0],[0.127,0.004,0.005],[2.087,0.012,0.013],[1.696,0.016,0.02],[1.762,0.137,0.156],[2.825,0.137,0.134],[0.074,0.013,0.015],[0.647,0.006,0.006],[2.814,0.167,0.172],[4.349,0.19,0.202],[2.723,0.07,0.077],[3.358,0.072,0.081],[3.098,0.123,0.136],[4.768,0.215,0.24],[3.11,0.128,0.139],[1.151,0.301,0.157],[4.613,0.282,0.303],[4.616,0.298,0.318],[8.003,0.41,0.432],[0.326,0.002,0.002],[23.668,0.134,0.069],[26.046,0.06,0.052],[41.279,0.117,0.101],[4.594,0.04,0.033],[1.256,0.021,0.029],[1.75,0.156,0.027],[1.763,0.033,0.007],[24.033,0.074,0.06],[17.846,0.819,0.704],[0.363,0.021,0.02],[7.522,0.117,0.124],[10.721,0.23,0.272],[7.48,0.439,0.612],[23.106,0.455,0.563],[23.144,0.494,0.557],[0.703,0.239,0.248],[0.1,0.02,0.02],[0.072,0.01,0.011],[0.084,0.01,0.009],[0.14,0.04,0.04],[0.06,0.003,0.003],[0.053,0.004,0.004],[0.048,0.006,0.006]],"source":"duckdb/results/c8g.metal-48xl.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":102,"data_size":20559704064,"result":[[0.033,0,0.001],[0.208,0.005,0.002],[2.098,0.005,0.004],[1.655,0.007,0.008],[1.727,0.083,0.081],[2.255,0.08,0.092],[0.136,0.004,0.002],[0.594,0.005,0.005],[2.828,0.102,0.1],[4.534,0.126,0.128],[2.381,0.031,0.03],[3.23,0.031,0.03],[2.401,0.095,0.09],[4.03,0.276,0.161],[2.937,0.102,0.116],[1.265,0.094,0.088],[4.16,0.173,0.348],[3.944,0.37,0.157],[7.416,0.326,0.307],[0.35,0.007,0.005],[16.224,0.082,0.075],[18.035,0.13,0.074],[16.822,0.21,0.268],[2.768,0.484,0.222],[0.701,0.036,0.435],[2.516,0.025,0.025],[0.824,0.042,0.009],[16.699,0.327,0.072],[12.632,1.101,1.055],[0.425,0.011,0.011],[7.417,0.079,0.071],[10.349,0.101,0.089],[8.05,0.473,0.462],[15.765,0.43,0.292],[15.936,0.424,0.352],[0.737,0.102,0.096],[0.101,0.025,0.024],[0.065,0.008,0.008],[0.087,0.011,0.013],[0.158,0.053,0.05],[0.079,0.006,0.006],[0.067,0.007,0.008],[0.069,0.009,0.008]],"source":"duckdb/results/c6a.metal.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":251,"data_size":20548431872,"result":[[0.03,0.001,0],[0.436,0.009,0.009],[0.936,0.067,0.066],[0.945,0.123,0.124],[1.483,0.808,0.829],[1.838,0.752,0.767],[0.315,0.016,0.016],[0.491,0.013,0.013],[2.116,1.045,1.069],[3.193,1.523,1.551],[1.508,0.235,0.235],[1.696,0.267,0.264],[1.879,0.802,0.816],[3.186,1.548,1.537],[2.286,0.923,0.946],[1.68,0.938,0.953],[3.768,2.191,2.25],[3.208,1.552,1.588],[7.199,4.674,4.718],[0.492,0.009,0.009],[11.566,1.84,1.831],[13.171,1.912,1.895],[17.561,4.438,2.731],[1.587,0.626,0.639],[0.438,0.067,0.058],[1.282,0.249,0.246],[0.407,0.063,0.049],[11.828,1.502,1.535],[30.088,27.487,27.563],[0.649,0.09,0.092],[4.62,0.773,0.803],[7.653,0.961,0.992],[8.72,7.876,8.12],[12.252,8.446,8.339],[12.434,9.463,9.838],[1.826,1.245,1.279],[0.197,0.046,0.085],[0.117,0.01,0.016],[0.156,0.069,0.064],[0.314,0.226,0.234],[0.145,0.006,0.007],[0.127,0.007,0.007],[0.118,0.019,0.018]],"source":"duckdb/results/c6a.xlarge.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":101,"data_size":20560490496,"result":[[0.032,0,0],[0.299,0.004,0.004],[1.984,0.005,0.003],[1.714,0.004,0.004],[1.793,0.07,0.066],[2.256,0.07,0.067],[0.139,0.003,0.003],[0.668,0.006,0.006],[2.88,0.079,0.077],[4.62,0.1,0.099],[2.46,0.028,0.025],[3.28,0.029,0.026],[2.442,0.084,0.08],[4.086,0.218,0.211],[2.937,0.089,0.091],[1.196,0.075,0.072],[4.261,0.143,0.34],[3.942,0.142,0.141],[7.411,0.291,0.265],[0.349,0.006,0.007],[16.226,0.059,0.053],[18.046,0.065,0.052],[16.796,0.357,0.134],[2.882,0.549,0.105],[0.9,0.041,0.01],[2.571,0.036,0.023],[0.946,0.037,0.013],[16.739,0.245,0.061],[12.573,0.757,0.672],[0.423,0.011,0.011],[7.481,0.067,0.06],[10.42,0.085,0.076],[8.021,0.391,0.348],[15.752,0.309,0.223],[15.835,0.366,0.287],[0.73,0.079,0.074],[0.095,0.022,0.021],[0.058,0.007,0.007],[0.091,0.011,0.01],[0.156,0.046,0.044],[0.078,0.005,0.006],[0.063,0.007,0.007],[0.068,0.008,0.008]],"source":"duckdb/results/c7a.metal-48xl.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":113,"data_size":20550004736,"result":[[0.019,0.001,0],[0.089,0.002,0.002],[1.078,0.012,0.012],[1.096,0.02,0.019],[1.122,0.134,0.135],[1.375,0.144,0.141],[0.083,0.003,0.002],[0.249,0.003,0.003],[1.916,0.179,0.179],[2.847,0.264,0.272],[1.325,0.039,0.039],[2.157,0.044,0.043],[1.519,0.157,0.156],[2.647,0.304,0.304],[1.691,0.181,0.178],[0.665,0.158,0.158],[2.656,0.361,0.365],[2.361,0.284,0.29],[4.987,0.66,0.678],[0.121,0.002,0.002],[11.324,0.304,0.303],[12.417,0.308,0.296],[15.791,1.627,1.474],[0.97,0.074,1.195],[0.131,0.015,0.013],[1.255,0.04,0.04],[0.291,0.011,0.01],[11.744,0.217,0.223],[8.665,3.54,3.536],[0.162,0.019,0.018],[4.338,0.144,0.15],[7.193,0.168,0.229],[5.476,0.737,0.773],[10.901,0.797,0.779],[10.891,0.86,0.85],[0.362,0.198,0.206],[0.094,0.015,0.016],[0.065,0.005,0.008],[0.081,0.009,0.009],[0.142,0.04,0.035],[0.08,0.003,0.003],[0.067,0.004,0.004],[0.066,0.005,0.006]],"source":"duckdb/results/c8g.4xlarge.json"}
+,{"system":"DuckDB","date":"2025-10-09","machine":"c8g.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["C++","column-oriented","embedded"],"load_time":94,"data_size":20558393344,"result":[[0.023,0,0.001],[0.187,0.002,0.002],[2.184,0.003,0.003],[1.742,0.003,0.004],[1.823,0.05,0.053],[2.356,0.07,0.067],[0.107,0.002,0.003],[0.739,0.005,0.003],[2.853,0.061,0.061],[4.637,0.082,0.078],[2.547,0.019,0.02],[3.344,0.021,0.024],[2.441,0.069,0.071],[4.085,0.179,0.184],[2.9,0.08,0.072],[1.181,0.057,0.056],[4.225,0.116,0.101],[3.923,0.122,0.109],[7.406,0.217,0.191],[0.348,0.003,0.003],[16.256,0.142,0.055],[18.017,0.066,0.05],[16.944,0.436,0.121],[2.694,0.6,0.194],[0.736,0.042,0.014],[2.613,0.037,0.037],[1.173,0.042,0.009],[16.722,0.139,0.04],[12.345,0.563,0.508],[0.416,0.011,0.008],[7.476,0.047,0.045],[10.402,0.06,0.057],[8.034,0.439,0.325],[15.735,0.4,0.199],[15.805,0.39,0.26],[0.706,0.06,0.059],[0.079,0.02,0.019],[0.046,0.006,0.005],[0.068,0.009,0.009],[0.136,0.041,0.041],[0.061,0.004,0.006],[0.05,0.005,0.005],[0.054,0.006,0.007]],"source":"duckdb/results/c8g.metal-48xl.json"}
,{"system":"Elasticsearch","date":"2025-09-08","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","search"],"load_time":9531,"data_size":85859504096,"result":[[0.088,0.002,0.003],[0.162,0.005,0.004],[0.775,0.615,0.587],[1.904,0.272,0.294],[0.326,0.335,0.287],[1.43,0.557,0.517],[0.317,0.302,0.317],[0.96,0.862,0.865],[9.273,8.909,8.773],[13.188,12.709,12.939],[1.608,1.142,1.143],[1.802,1.522,1.531],[4.371,4.215,4.216],[4.244,4.254,4.211],[4.647,4.43,4.537],[0.845,0.805,0.877],[8.333,8.709,8.756],[8.684,8.546,8.62],[19.984,20.234,19.957],[0.135,0.004,0.003],[27.196,14.498,14.516],[19.142,17.073,17.127],[37.757,26.757,26.835],[14.545,14.498,14.489],[0.849,0.778,0.776],[1.652,1.622,1.627],[0.782,0.775,0.779],[89.371,85.607,85.682],[null,null,null],[120.908,127.011,128.136],[3.199,1.638,1.627],[5.097,1.73,1.679],[5.747,5.988,5.623],[13.781,12.778,12.715],[12.657,12.604,12.722],[23.429,23.336,23.306],[8.353,8.216,8.196],[6.981,6.46,6.447],[8.32,8.169,8.095],[13.614,12.761,12.76],[0.109,0.026,0.028],[0.059,0.021,0.021],[0.254,0.165,0.164]],"source":"elasticsearch/results/c6a.4xlarge.json"}
,{"system":"Elasticsearch (tuned)","date":"2025-09-02","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"yes","comment":"Tuned by repeated benchmark to find the optimal Elasticsearch shard number and size for this resource type and workload","tags":["Java","search"],"load_time":7139.561,"data_size":114316150384,"result":[[0.0620,0.0020,0.0020],[0.0200,0.0030,0.0030],[0.9730,0.8710,0.8890],[5.1100,0.3980,0.3740],[0.5320,0.4980,0.4930],[3.2420,0.8860,0.8630],[0.4520,0.4350,0.4540],[0.3740,0.2340,0.2280],[2.7970,2.2750,2.2560],[3.4130,3.3060,3.3680],[0.3830,0.2790,0.2920],[0.4510,0.3290,0.3310],[0.3390,0.3110,0.3080],[0.3270,0.3450,0.3510],[0.4150,0.3590,0.3720],[0.9740,0.9470,0.9420],[1.1460,1.1570,1.1540],[1.1660,1.2110,1.1000],[4.3910,4.2280,3.8750],[0.0540,0.0030,0.0030],[16.4180,4.5470,4.5320],[5.0100,4.5980,4.5680],[17.6210,7.5370,7.6240],[4.5460,4.5480,4.5400],[0.3210,0.2520,0.2490],[0.5070,0.4260,0.4230],[0.2710,0.2390,0.2390],[28.7840,27.4500,27.2160],[null,null,null],[224.5530,228.1640,229.3260],[2.3680,0.4550,0.4540],[5.3140,0.4490,0.4470],[1.4670,1.4520,1.4980],[0.8390,0.8500,0.8300],[0.8430,0.8310,0.8060],[6.9170,6.8400,6.6780],[0.0790,0.1000,0.0280],[0.1310,0.0240,0.0340],[0.0210,0.0170,0.0180],[1.9500,1.3690,1.3750],[0.0600,0.0180,0.0200],[0.0200,0.0110,0.0160],[0.1310,0.0560,0.0450]],"source":"elasticsearch/results/c6a.4xlarge.tuned.json"}
,{"system":"Elasticsearch","date":"2025-09-08","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","search"],"load_time":9565,"data_size":84661395365,"result":[[0.044,0.003,0.002],[0.017,0.004,0.003],[0.704,0.554,0.532],[0.245,0.305,0.238],[0.336,0.283,0.275],[0.624,0.504,0.497],[0.25,0.288,0.253],[0.853,0.949,0.92],[8.62,9.334,9.534],[13.03,13.877,13.726],[1.225,1.154,1.13],[1.444,1.399,1.439],[4.18,4.302,4.334],[4.427,4.503,4.398],[4.518,4.512,4.589],[0.673,0.699,0.586],[7.563,8.279,8.639],[8.101,7.472,7.811],[22.166,20.908,21.667],[0.046,0.004,0.004],[12.686,12.562,12.471],[15.251,15.386,15.156],[23.839,23.755,23.836],[12.482,12.468,12.507],[0.785,0.754,0.75],[1.544,1.528,1.596],[0.854,0.771,0.756],[94.97,94.304,93.238],[null,null,null],[301.037,479.109,446.655],[1.576,1.566,1.57],[1.709,1.667,1.639],[5.603,6.779,6.842],[14.281,12.727,12.625],[13.275,14.216,12.885],[25.094,29.899,25.758],[8.423,8.498,8.379],[6.768,6.671,6.597],[8.298,8.328,8.258],[13.297,13.245,13.205],[0.045,0.034,0.032],[0.027,0.025,0.027],[0.237,0.199,0.197]],"source":"elasticsearch/results/c6a.metal.json"}
@@ -260,11 +270,12 @@ const data = [
,{"system":"Salesforce Hyper (Parquet)","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":0,"data_size":14737666736,"result":[[1.283,0.085,0.084],[1.369,0.167,0.162],[2.328,0.623,0.625],[2.627,0.434,0.433],[4.007,2.078,2.075],[3.948,2.449,2.427],[1.517,0.383,0.382],[1.225,0.157,0.157],[4.846,2.968,2.917],[5.384,3.617,3.528],[2.877,0.418,0.415],[2.085,0.494,0.493],[3.826,2.245,2.246],[6.981,5.099,4.973],[3.908,2.363,2.383],[3.778,2.273,2.236],[6.244,4.342,4.325],[5.992,4.04,4.004],[90.626,89.575,91.629],[1.649,0.159,0.156],[10.595,3.457,3.535],[12.151,3.722,3.721],[20.771,11.991,12.025],[49.013,49.233,49.153],[3.872,1.645,1.65],[2.805,1.409,1.412],[3.869,1.651,1.649],[10.756,4.202,4.209],[14.085,11.674,11.725],[18.545,17.358,17.195],[4.683,2.609,2.635],[8.033,3.137,3.113],[172.187,172.248,171.47],[null,null,null],[null,null,null],[3.594,2.053,2.044],[1.286,0.11,0.11],[1.279,0.129,0.128],[1.256,0.05,0.051],[1.417,0.215,0.211],[1.11,0.037,0.036],[1.208,0.036,0.037],[1.124,0.054,0.058]],"source":"hyper-parquet/results/c6a.xlarge.json"}
,{"system":"Salesforce Hyper (Parquet)","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":0,"data_size":14737666736,"result":[[0.672,0.015,0.014],[1.633,0.014,0.015],[2.128,0.032,0.037],[2.793,0.036,0.036],[2.873,0.117,0.113],[3.095,0.142,0.132],[1.45,0.026,0.025],[1.828,0.016,0.017],[3.16,0.137,0.137],[3.453,0.164,0.161],[2.569,0.039,0.042],[2.928,0.043,0.045],[3.071,0.144,0.141],[4.497,0.295,0.3],[2.738,0.141,0.145],[2.621,0.121,0.116],[4.43,0.247,0.236],[4.095,0.202,0.204],[6.314,0.456,0.411],[1.727,0.024,0.027],[11.901,0.223,0.214],[12.929,0.237,0.21],[21.379,0.499,0.439],[49.993,0.973,0.96],[4.277,0.109,0.12],[2.996,0.092,0.087],[4.988,0.109,0.112],[11.236,0.259,0.235],[9.074,0.527,0.523],[0.88,0.3,0.319],[3.635,0.146,0.152],[7.219,0.207,0.208],[6.005,0.531,0.538],[10.762,0.464,0.421],[10.782,0.432,0.446],[1.341,0.113,0.101],[0.665,0.092,0.091],[0.634,0.084,0.086],[0.652,0.033,0.035],[0.846,0.175,0.168],[0.607,0.022,0.022],[0.672,0.02,0.021],[0.603,0.038,0.036]],"source":"hyper-parquet/results/c7a.metal-48xl.json"}
,{"system":"Salesforce Hyper (Parquet)","date":"2025-08-31","machine":"t3a.small","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":0,"data_size":14737666736,"result":[[4.416,0.27,0.268],[5.244,0.61,0.606],[6.584,2.025,2.022],[6.532,1.401,1.407],[32.133,27.964,27.469],[null,null,null],[5.551,1.219,1.223],[4.946,0.481,0.611],[42.941,38.233,38.486],[48.027,43.101,44.161],[6.541,1.455,1.446],[7.175,1.818,1.802],[null,null,null],[null,null,null],[null,null,null],[48.811,46.138,46.224],[null,null,null],[null,null,null],[null,null,null],[5.502,0.58,0.574],[19.459,15.691,15.406],[21.232,17.413,17.436],[51.723,46.92,47.528],[null,null,null],[10.935,5.11,5.191],[9.163,4.411,4.412],[11.122,5.137,5.147],[22.979,18.422,18.623],[null,null,null],[118.781,114.765,114.705],[14.366,9.092,8.911],[52.04,46.888,46.461],[289.845,285.724,285.351],[null,null,null],[null,null,null],[40.651,34.747,34.795],[4.527,0.262,0.264],[4.537,0.283,0.298],[4.569,0.137,0.13],[4.965,0.446,0.448],[4.228,0.105,0.103],[4.531,0.094,0.108],[4.326,0.144,0.146]],"source":"hyper-parquet/results/t3a.small.json"}
-,{"system":"Salesforce Hyper","date":"2025-07-10","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":686,"data_size":18959040512,"result":[[0.038,0.01,0.01],[0.157,0.017,0.017],[0.478,0.057,0.057],[1.093,0.056,0.056],[1.121,0.875,0.885],[2.195,0.341,0.34],[0.133,0.002,0.002],[0.19,0.018,0.017],[2.413,1.24,1.244],[3.906,1.335,1.333],[1.19,0.09,0.089],[1.209,0.096,0.095],[2.207,0.55,0.561],[5.262,1.854,1.883],[2.263,0.62,0.624],[1.666,1.067,1.069],[5.019,1.61,1.62],[4.592,1.444,1.447],[9.284,3.37,3.439],[0.21,0.002,0.002],[14.784,0.643,0.643],[19.204,0.641,0.657],[17.137,0.428,0.425],[64.173,29.257,13.603],[5.485,0.104,0.105],[1.984,0.104,0.104],[5.488,0.105,0.105],[17.736,0.936,1.138],[12.672,4.397,4.41],[1.15,0.971,0.97],[5.316,0.544,0.534],[8.832,0.847,0.843],[9.829,6.197,6.216],[15.53,2.303,2.312],[18.027,2.505,2.301],[1.159,0.921,0.911],[0.194,0.017,0.017],[0.166,0.006,0.005],[0.177,0.004,0.003],[0.28,0.031,0.032],[0.279,0.002,0.002],[0.28,0.003,0.003],[0.165,0.005,0.004]],"source":"hyper/results/c6a.2xlarge.json"}
-,{"system":"Salesforce Hyper","date":"2025-07-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":687,"data_size":18959040512,"result":[[0.036,0.006,0.006],[0.096,0.009,0.009],[0.476,0.03,0.029],[1.094,0.03,0.029],[0.984,0.581,0.564],[2.117,0.16,0.16],[0.09,0.003,0.003],[0.106,0.01,0.009],[2.179,0.795,0.804],[3.702,0.836,0.834],[1.18,0.048,0.048],[1.185,0.051,0.051],[2.162,0.298,0.3],[4.773,0.956,0.958],[2.169,0.298,0.3],[1.487,0.688,0.688],[4.648,1.011,1.028],[4.428,0.896,0.883],[8.694,2.079,2.1],[0.147,0.003,0.003],[17.196,0.419,0.395],[16.212,0.396,0.399],[17.853,0.304,0.335],[55.378,0.523,0.511],[5.488,0.06,0.059],[1.984,0.057,0.057],[5.49,0.063,0.062],[15.914,0.677,0.696],[12.657,2.297,2.309],[0.619,0.488,0.488],[4.974,0.278,0.279],[8.976,0.522,0.518],[8.216,3.848,3.808],[17.794,1.449,1.469],[15.345,1.463,1.479],[0.958,0.638,0.636],[0.131,0.012,0.011],[0.116,0.005,0.004],[0.115,0.004,0.004],[0.236,0.022,0.022],[0.171,0.004,0.003],[0.17,0.004,0.004],[0.117,0.005,0.004]],"source":"hyper/results/c6a.4xlarge.json"}
-,{"system":"Salesforce Hyper","date":"2024-01-17","machine":"c6a.metal","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":413,"data_size":18959040512,"result":[[0.027,0.018,0.005],[0.075,0.022,0.011],[0.477,0.016,0.015],[1.102,0.026,0.025],[0.672,0.092,0.083],[2.029,0.056,0.060],[0.076,0.015,0.020],[0.070,0.011,0.016],[1.865,0.148,0.149],[3.330,0.167,0.172],[1.174,0.029,0.052],[1.185,0.021,0.023],[2.043,0.068,0.068],[4.231,0.242,0.240],[2.045,0.074,0.075],[1.254,0.174,0.164],[4.217,0.208,0.208],[4.160,0.147,0.153],[8.140,0.498,0.514],[0.123,0.014,0.013],[14.915,0.092,0.078],[16.253,0.072,0.066],[17.236,0.057,0.058],[41.629,0.091,0.083],[5.490,0.016,0.019],[1.989,0.014,0.015],[5.492,0.015,0.016],[15.379,0.095,0.092],[12.728,0.367,0.383],[0.229,0.054,0.054],[4.880,0.067,0.066],[8.411,0.093,0.097],[6.423,0.757,0.761],[15.299,0.302,0.310],[14.980,0.266,0.269],[0.757,0.127,0.122],[0.117,0.024,0.022],[0.105,0.030,0.014],[0.107,0.016,0.025],[0.157,0.037,0.040],[0.142,0.018,0.018],[0.142,0.017,0.017],[0.089,0.017,0.017]],"source":"hyper/results/c6a.metal.json"}
-,{"system":"Salesforce Hyper","date":"2025-08-31","machine":"c6a.xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":661,"data_size":18959040512,"result":[[0.054,0.021,0.021],[0.299,0.037,0.036],[0.753,0.114,0.114],[1.101,0.108,0.108],[1.872,1.427,1.43],[2.309,0.667,0.68],[0.256,0.002,0.001],[0.293,0.038,0.037],[2.862,2.07,1.972],[4.243,2.111,2.127],[1.4,0.168,0.167],[1.447,0.178,0.172],[2.458,0.993,1.074],[6.207,3.38,3.382],[2.547,1.034,1.045],[2.468,1.821,1.801],[5.649,2.798,2.984],[5.001,2.466,2.484],[10.603,6.097,6.08],[0.435,0.002,0.002],[16.277,1.508,1.165],[20.091,1.141,1.129],[22.119,0.739,0.737],[72.69,55,43.277],[5.486,0.205,0.205],[1.986,0.204,0.204],[5.514,0.206,0.205],[17.741,1.821,1.823],[15.248,8.727,8.815],[2.109,1.895,1.856],[5.214,0.929,0.933],[9.177,1.461,1.445],[154.67,155.619,151.901],[19.148,4.246,4.176],[17.437,4.307,4.142],[2.028,1.533,1.528],[0.39,0.029,0.027],[0.298,0.01,0.009],[0.308,0.005,0.004],[0.523,0.056,0.055],[0.523,0.003,0.002],[0.53,0.004,0.003],[0.287,0.007,0.007]],"source":"hyper/results/c6a.xlarge.json"}
-,{"system":"Salesforce Hyper","date":"2025-08-30","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":368,"data_size":18959040512,"result":[[0.025,0.004,0.005],[0.091,0.006,0.009],[0.476,0.006,0.006],[1.432,0.006,0.006],[0.953,0.075,0.07],[2.09,0.036,0.038],[0.059,0.001,0.002],[0.058,0.011,0.009],[1.823,0.115,0.118],[3.273,0.12,0.123],[1.168,0.016,0.014],[1.452,0.015,0.014],[2.298,0.046,0.045],[4.189,0.136,0.129],[2.043,0.052,0.052],[1.245,0.107,0.132],[4.18,0.145,0.139],[4.136,0.113,0.11],[8.186,0.52,0.521],[0.115,0.002,0.001],[14.891,0.057,0.049],[16.424,0.055,0.055],[17.166,0.038,0.036],[41.655,0.058,0.055],[5.482,0.008,0.008],[2.146,0.008,0.008],[5.775,0.01,0.009],[15.499,0.08,0.077],[12.674,0.379,0.339],[0.195,0.04,0.036],[5.03,0.051,0.051],[8.391,0.071,0.076],[6.362,0.659,0.643],[14.969,0.189,0.18],[14.916,0.212,0.186],[0.713,0.098,0.098],[0.096,0.007,0.007],[0.088,0.004,0.004],[0.113,0.004,0.004],[0.132,0.013,0.013],[0.19,0.006,0.005],[0.151,0.004,0.004],[0.086,0.004,0.004]],"source":"hyper/results/c7a.metal-48xl.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-16","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":649,"data_size":18959040512,"result":[[0.049,0.011,0.011],[0.17,0.019,0.019],[0.486,0.058,0.058],[1.248,0.055,0.055],[1.145,0.9,0.899],[2.203,0.341,0.344],[0.148,0.001,0.001],[0.169,0.02,0.019],[2.473,1.262,1.226],[3.913,1.434,1.355],[1.195,0.087,0.086],[1.201,0.093,0.092],[2.178,0.565,0.573],[5.371,1.871,1.87],[2.233,0.632,0.63],[1.84,1.115,1.101],[4.98,1.642,1.663],[4.72,1.436,1.452],[9.445,3.458,3.524],[0.239,0.002,0.001],[14.698,0.637,0.639],[16.616,0.632,0.632],[17.021,0.42,0.418],[64.069,27.022,16.026],[5.455,0.108,0.106],[1.949,0.107,0.107],[5.456,0.109,0.109],[15.659,0.965,0.965],[12.59,4.394,4.405],[1.11,0.931,0.932],[5.402,0.537,0.536],[8.939,0.843,0.88],[10.029,6.223,6.216],[15.445,2.339,2.317],[15.868,2.328,2.316],[1.292,0.956,0.955],[0.218,0.018,0.016],[0.176,0.006,0.005],[0.188,0.004,0.003],[0.291,0.033,0.031],[0.337,0.003,0.002],[0.295,0.003,0.003],[0.172,0.005,0.004]],"source":"hyper/results/c6a.2xlarge.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-16","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":673,"data_size":18959040512,"result":[[0.041,0.006,0.006],[0.114,0.01,0.01],[0.481,0.03,0.03],[1.419,0.03,0.029],[1.133,0.562,0.569],[2.118,0.161,0.159],[0.091,0.001,0.001],[0.102,0.011,0.01],[2.246,0.806,0.781],[3.695,0.839,0.832],[1.17,0.047,0.047],[1.301,0.05,0.049],[2.187,0.291,0.293],[4.85,0.958,0.963],[2.131,0.301,0.302],[1.641,0.71,0.713],[4.663,1.01,1.003],[4.535,0.9,0.885],[8.813,2.062,2.076],[0.144,0.002,0.001],[15.137,0.378,0.378],[16.307,0.379,0.378],[17.195,0.252,0.252],[54.612,0.493,0.485],[5.453,0.058,0.057],[1.945,0.059,0.058],[5.467,0.059,0.058],[15.383,0.529,0.527],[12.555,2.275,2.277],[0.611,0.47,0.47],[5.322,0.275,0.274],[8.731,0.461,0.461],[8.217,3.694,3.679],[15.608,1.414,1.42],[15.378,1.409,1.423],[1.135,0.631,0.632],[0.31,0.012,0.011],[0.303,0.005,0.004],[0.235,0.004,0.003],[0.235,0.022,0.021],[0.252,0.002,0.001],[0.181,0.003,0.002],[0.119,0.004,0.004]],"source":"hyper/results/c6a.4xlarge.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-16","machine":"c6a.large","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":781,"data_size":18959040512,"result":[[0.077,0.042,0.043],[0.534,0.073,0.073],[1.443,0.226,0.226],[1.967,0.219,0.219],[3.502,2.581,2.632],[2.824,1.187,1.19],[0.463,0.002,0.002],[0.521,0.075,0.075],[5.251,3.238,3.2],[6.6,3.78,3.617],[2.771,0.36,0.358],[2.882,0.363,0.368],[4.87,1.741,1.755],[10.992,6.142,6.165],[5.07,1.848,1.855],[4.858,3.142,3.052],[10.4,5.469,4.927],[9.671,4.806,4.398],[114.993,120.63,120.087],[0.816,0.004,0.004],[20.329,22.671,23.913],[22.507,24.243,25.628],[23.602,20.991,20.593],[74.987,70.269,68.871],[6.249,0.399,0.396],[3.515,0.407,0.401],[6.22,0.403,0.403],[22.288,25.39,25.348],[33.542,31.051,30.708],[4.179,3.715,3.786],[6.977,1.712,1.732],[10.834,4.453,2.885],[172.245,175.589,176.369],[478.941,461.72,470.315],[479.096,456.128,456.587],[3.67,2.349,2.345],[0.76,0.056,0.05],[0.563,0.019,0.018],[0.569,0.008,0.007],[1.003,0.104,0.1],[0.998,0.004,0.004],[1.014,0.006,0.006],[0.524,0.012,0.012]],"source":"hyper/results/c6a.large.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-15","machine":"c6a.metal","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":441,"data_size":18959040512,"result":[[0.031,0.007,0.006],[0.063,0.005,0.005],[0.475,0.006,0.006],[1.671,0.01,0.009],[1.119,0.131,0.126],[2.041,0.059,0.061],[0.062,0.002,0.001],[0.077,0.013,0.018],[1.926,0.155,0.15],[3.38,0.154,0.162],[1.159,0.034,0.018],[1.437,0.02,0.019],[2.324,0.076,0.078],[4.441,0.268,0.272],[2.01,0.084,0.079],[1.396,0.15,0.149],[4.328,0.197,0.18],[4.27,0.137,0.145],[8.513,0.678,0.668],[0.087,0.001,0.001],[14.881,0.096,0.073],[16.118,0.096,0.083],[17.022,0.072,0.069],[41.498,0.092,0.09],[5.454,0.026,0.022],[2.131,0.019,0.017],[5.738,0.017,0.017],[15.325,0.144,0.108],[12.618,0.38,0.388],[0.195,0.056,0.055],[5.198,0.072,0.072],[8.517,0.112,0.111],[6.689,0.847,0.85],[14.962,0.394,0.397],[14.926,0.31,0.313],[0.944,0.137,0.125],[0.102,0.01,0.01],[0.079,0.005,0.004],[0.091,0.004,0.003],[0.125,0.021,0.021],[0.114,0.006,0.005],[0.385,0.004,0.004],[0.074,0.005,0.005]],"source":"hyper/results/c6a.metal.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-16","machine":"c6a.xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":639,"data_size":18959040512,"result":[[0.058,0.021,0.021],[0.282,0.037,0.037],[0.729,0.114,0.114],[1.249,0.108,0.109],[1.887,1.444,1.452],[2.314,0.674,0.666],[0.249,0.001,0.001],[0.283,0.038,0.038],[2.924,2.11,2.081],[4.347,2.29,2.246],[1.386,0.173,0.17],[1.443,0.185,0.189],[2.478,1.013,1.018],[6.278,3.369,3.371],[2.571,1.075,1.062],[2.505,1.845,1.758],[5.414,2.852,2.85],[5.305,2.487,2.546],[10.647,6.134,6.095],[0.428,0.003,0.002],[15.286,1.154,1.149],[17.591,1.156,1.146],[19.608,0.762,0.76],[72.316,51.118,42.771],[5.462,0.201,0.199],[1.954,0.205,0.206],[5.465,0.205,0.205],[15.819,1.824,1.825],[15.249,8.738,8.74],[2.133,1.914,1.858],[5.319,0.938,0.935],[9.225,1.438,1.447],[148.899,151.44,155.5],[16.889,4.356,4.12],[17.113,4.192,4.261],[2.053,1.523,1.533],[0.387,0.027,0.027],[0.298,0.01,0.009],[0.31,0.005,0.004],[0.523,0.056,0.053],[0.526,0.003,0.002],[0.532,0.004,0.004],[0.288,0.007,0.007]],"source":"hyper/results/c6a.xlarge.json"}
+,{"system":"Salesforce Hyper","date":"2025-10-15","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["C++","column-oriented"],"load_time":387,"data_size":18959040512,"result":[[0.037,0.005,0.005],[0.065,0.006,0.01],[0.474,0.006,0.006],[1.725,0.006,0.006],[1.106,0.081,0.078],[2.193,0.037,0.038],[0.058,0.002,0.001],[0.058,0.007,0.007],[1.961,0.138,0.137],[3.34,0.142,0.127],[1.149,0.015,0.015],[1.593,0.018,0.018],[2.388,0.054,0.053],[4.471,0.156,0.146],[1.994,0.055,0.052],[1.538,0.108,0.109],[4.398,0.154,0.154],[4.258,0.123,0.116],[8.297,0.557,0.54],[0.118,0.001,0.001],[14.903,0.061,0.053],[16.126,0.053,0.048],[17.025,0.045,0.043],[41.526,0.066,0.054],[5.452,0.01,0.009],[2.198,0.009,0.009],[5.848,0.01,0.009],[15.347,0.084,0.073],[12.591,0.376,0.327],[0.189,0.048,0.046],[5.245,0.051,0.052],[8.536,0.08,0.08],[6.693,0.727,0.707],[14.847,0.238,0.19],[14.843,0.201,0.189],[0.886,0.101,0.095],[0.099,0.008,0.008],[0.077,0.004,0.004],[0.086,0.004,0.004],[0.123,0.016,0.016],[0.281,0.006,0.005],[0.531,0.004,0.004],[0.068,0.006,0.005]],"source":"hyper/results/c7a.metal-48xl.json"}
,{"system":"Infobright","date":"2022-07-01","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","comment":"Only 90% of data successfully loaded. Some queries run for days.","tags":["C++","column-oriented","MySQL compatible"],"load_time":2317,"data_size":13760341294,"result":[[0.01,0,0],[2.39,2.4,2.44],[0,0,0],[7.21,6.04,6.91],[16.09,16.86,15.69],[48.8,42.37,48.63],[0,0,0],[3.48,2.42,2.42],[23.56,24.78,22.21],[32.87,31.71,34.48],[14.8,14.83,14.11],[16.7,16.53,17.37],[1752.91,1999.88,1961.4],[1193.43,1167,1220.47],[2184.81,2316.12,2224.14],[32.58,30.69,31.58],[300.17,16221.33,16168.44],[122.4,120.49,124.67],[78927.44,79250.44,78504.89],[3.38,1.22,1.21],[289.73,302.3,285.83],[415.82,389.23,403.28],[573.82,590.81,575.06],[300.13,293.96,285.64],[41.42,37.48,39.64],[75.2,75.37,72.07],[39.22,41.52,40.11],[449.56,445.03,448.68],[null,null,null],[450.87,488.3,453.83],[58.69,59.29,58.07],[84.47,78.92,79.38],[517.97,520.29,504.96],[182468.89,182468.89,182468.89],[182468.89,182468.89,182468.89],[68.43,66.93,67.68],[8.3,3.62,3.61],[1.04,0.62,0.62],[0.22,0.18,0.18],[567.78,566.52,563.02],[0.29,0.14,0.11],[0.17,0.08,0.08],[1.37,1.34,1.32]],"source":"infobright/results/c6a.4xlarge.json"}
,{"system":"Kinetica","date":"2025-07-10","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["column-oriented"],"load_time":668,"data_size":57932249716,"result":[[0.128,0.052,0.05],[0.222,0.119,0.06],[0.21,0.082,0.052],[1.424,0.114,0.051],[1.896,1.86,1.1],[4.648,1.747,1.349],[1.422,0.523,0.577],[1.461,0.118,0.06],[2.993,2.905,0.805],[3.035,2.972,2.703],[0.598,0.513,0.488],[0.606,0.51,0.501],[2.844,2.838,2.748],[3.953,3.893,3.821],[2.965,2.97,3.102],[2.163,2.159,2.14],[6.704,6.598,6.62],[3.038,3.003,2.936],[8.822,8.65,8.712],[0.103,0.075,0.054],[34.72,0.612,0.06],[0.714,0.61,0.065],[75.007,78.936,0.075],[8.83,0.117,0.118],[2.368,0.164,0.096],[0.167,0.138,0.142],[0.138,0.115,0.114],[35.713,0.633,0.061],[30.675,21.055,14.226],[0.283,0.102,0.089],[8.25,0.842,0.893],[3.049,1.143,1.174],[9.375,8.965,8.715],[44.103,10.103,10.309],[10.57,10.493,10.463],[1.489,1.41,1.418],[0.335,0.254,0.235],[0.33,0.096,0.092],[0.118,0.073,0.071],[0.816,0.466,0.464],[0.143,0.068,0.069],[0.12,0.064,0.066],[0.129,0.072,0.069]],"source":"kinetica/results/c6a.4xlarge.json"}
,{"system":"Kinetica","date":"2025-07-12","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"yes","tuned":"no","tags":["column-oriented"],"load_time":655,"data_size":57836683298,"result":[[4.331,0.062,0.056],[0.423,0.102,0.059],[0.237,0.061,0.056],[1.536,0.063,0.048],[0.967,0.906,0.737],[4.385,0.782,0.433],[0.239,0.063,0.05],[0.421,0.102,0.055],[1.45,1.281,0.632],[1.463,1.478,1.272],[0.439,0.305,0.31],[0.518,0.324,0.313],[2.308,2.219,2.224],[4.198,4.08,4.119],[2.383,2.293,2.308],[1.035,0.976,1.032],[6.284,3.618,3.622],[1.094,0.923,0.45],[5.37,4.722,4.757],[0.106,0.057,0.048],[34.458,0.393,0.055],[0.478,0.418,0.057],[74.642,85.627,0.08],[9.754,0.106,0.104],[2.547,0.112,0.081],[0.203,0.105,0.1],[0.196,0.102,0.088],[36.171,0.285,0.057],[31.555,30.025,20.086],[0.362,0.095,0.077],[8.12,0.5,0.575],[2.73,0.714,0.69],[4.609,4.805,4.503],[42.505,7.878,7.888],[8.031,8.087,8.088],[0.969,0.866,0.814],[0.569,0.234,0.24],[0.362,0.094,0.091],[0.126,0.077,0.072],[0.711,0.446,0.446],[0.155,0.072,0.07],[0.119,0.069,0.067],[0.125,0.066,0.066]],"source":"kinetica/results/c8g.4xlarge.json"}
@@ -343,6 +354,7 @@ const data = [
,{"system":"Redshift","date":"2022-07-29","machine":"Redshift: ra3.xlplus","cluster_size":4,"proprietary":"yes","tuned":"no","comment":"","tags":["managed","column-oriented","aws"],"load_time":2103,"data_size":21060648960,"result":[[0.079,0.033,0.034],[2.968,0.063,0.041],[4.080,0.130,0.108],[3.210,0.343,0.298],[4.544,0.631,0.582],[4.387,1.084,1.060],[3.068,0.108,0.082],[4.600,0.045,0.044],[5.016,0.911,0.867],[6.649,2.367,2.313],[5.443,0.309,0.290],[5.668,0.333,0.313],[5.188,1.085,1.149],[6.324,1.961,1.973],[5.492,1.144,1.123],[4.882,0.733,0.774],[6.401,2.257,2.278],[5.977,2.511,2.403],[7.838,3.470,3.546],[2.942,0.094,0.052],[5.742,2.535,2.498],[7.144,2.607,2.610],[13.254,6.773,6.784],[21.841,11.673,9.552],[4.594,0.474,0.478],[4.635,0.494,0.455],[4.832,0.474,0.474],[6.194,2.059,2.067],[12.694,7.745,7.737],[19.926,1.349,1.272],[6.178,0.845,0.858],[6.394,1.080,1.070],[8.112,3.869,3.986],[10.048,5.276,5.259],[9.260,5.163,5.210],[4.766,0.646,0.657],[7.602,1.880,1.884],[7.527,2.172,2.190],[5.570,0.229,0.228],[6.632,0.286,0.275],[4.224,0.103,0.077],[4.614,0.102,0.075],[4.389,0.052,0.050]],"source":"redshift/results/4x.ra3.xplus.json"}
,{"system":"Sail (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14737666736,"result":[[0.22,0.009,0.008],[0.305,0.033,0.034],[0.452,0.094,0.096],[0.614,0.102,0.096],[1.861,1.435,1.461],[1.852,1.359,1.329],[0.225,0.01,0.009],[0.318,0.037,0.035],[1.982,1.549,1.562],[2.313,1.65,1.636],[0.881,0.379,0.373],[0.911,0.399,0.407],[1.903,1.353,1.329],[3.624,2.257,2.273],[1.807,1.307,1.293],[2.09,1.609,1.549],[3.48,2.815,2.808],[3.445,2.833,2.687],[6.497,5.497,5.492],[0.606,0.092,0.092],[9.862,1.852,1.86],[11.61,2.059,2.121],[22.292,3.922,3.931],[55.788,45.072,45.066],[2.975,0.601,0.589],[1.032,0.491,0.482],[2.984,0.591,0.593],[9.905,2.589,2.607],[17.407,16.315,16.342],[1.281,1.008,1.022],[2.703,1.231,1.246],[6.326,1.247,1.242],[5.079,4.348,4.309],[11.7,6.664,6.802],[11.863,6.729,6.878],[2.148,1.747,1.671],[9.997,1.651,1.624],[8.993,1.563,1.578],[9.956,1.618,1.637],[18.739,2.933,2.913],[2.884,0.289,0.286],[2.07,0.266,0.273],[1.387,0.219,0.222]],"source":"sail-partitioned/results/c6a.2xlarge.json"}
,{"system":"Sail (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14737666736,"result":[[0.789,0.009,0.008],[0.356,0.023,0.022],[0.461,0.063,0.056],[0.61,0.063,0.063],[1.074,0.788,0.822],[1.267,0.824,0.8],[0.226,0.009,0.009],[0.296,0.025,0.025],[1.23,0.952,0.87],[1.636,0.986,1.003],[0.73,0.216,0.215],[0.835,0.232,0.24],[1.275,0.887,0.885],[3.117,1.475,1.527],[1.341,0.869,0.894],[1.286,0.907,0.905],[2.918,1.758,1.779],[2.9,1.702,1.669],[5.493,3.342,3.438],[0.6,0.06,0.059],[9.785,1.674,1.679],[11.534,1.876,1.927],[22.234,3.878,3.932],[55.726,10.609,10.713],[2.973,0.407,0.415],[0.976,0.276,0.277],[3.007,0.403,0.412],[9.887,2.427,2.446],[9.5,8.776,8.818],[0.83,0.566,0.562],[2.635,0.8,0.77],[6.343,0.962,0.959],[5.039,3.484,3.443],[11.07,5.319,5.308],[11.117,5.288,5.308],[1.347,1.032,1.028],[9.941,1.573,1.584],[8.936,1.47,1.454],[9.89,1.587,1.546],[18.698,2.946,2.975],[2.854,0.205,0.201],[2.05,0.17,0.167],[1.365,0.143,0.149]],"source":"sail-partitioned/results/c6a.4xlarge.json"}
+,{"system":"Sail (Parquet, partitioned)","date":"2025-10-09","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14737666736,"result":[[0.195,0.012,0.013],[0.299,0.039,0.045],[0.339,0.049,0.053],[0.51,0.064,0.062],[0.64,0.302,0.262],[0.962,0.303,0.274],[0.19,0.011,0.012],[0.29,0.064,0.079],[0.908,0.331,0.307],[1.381,0.406,0.36],[0.634,0.229,0.193],[0.755,0.22,0.199],[0.996,0.31,0.293],[2.446,0.436,0.458],[1.085,0.333,0.3],[0.717,0.402,0.37],[2.356,0.535,0.468],[2.272,0.453,0.399],[4.351,0.996,1.045],[0.485,0.051,0.064],[9.585,0.34,0.292],[11.221,0.473,0.378],[21.756,0.856,0.835],[55.811,2.815,2.608],[2.697,0.156,0.121],[0.881,0.112,0.102],[2.7,0.16,0.12],[9.626,0.513,0.549],[8.772,2.01,1.994],[0.43,0.219,0.203],[2.455,0.361,0.304],[5.94,0.494,0.4],[4.852,1.914,1.844],[10.144,1.563,1.649],[10.202,1.786,1.737],[0.805,0.39,0.334],[9.72,0.394,0.324],[8.751,0.375,0.294],[9.68,0.428,0.337],[18.566,0.65,0.545],[2.728,0.136,0.126],[1.92,0.114,0.109],[1.203,0.14,0.095]],"source":"sail-partitioned/results/c6a.metal.json"}
,{"system":"Sail (Parquet, partitioned)","date":"2025-10-09","machine":"c8g.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14737666736,"result":[[0.295,0.008,0.008],[0.249,0.022,0.021],[0.369,0.046,0.047],[0.577,0.043,0.042],[0.675,0.361,0.366],[1.173,0.564,0.555],[0.184,0.008,0.008],[0.233,0.023,0.024],[0.997,0.485,0.506],[1.479,0.674,0.664],[0.679,0.139,0.142],[0.78,0.158,0.157],[1.222,0.576,0.572],[2.668,0.805,0.688],[1.254,0.546,0.52],[0.747,0.444,0.432],[2.676,0.95,0.946],[2.67,0.958,0.956],[5.085,1.915,1.91],[0.574,0.043,0.043],[9.814,0.794,0.807],[11.537,0.846,0.835],[22.27,1.304,1.305],[55.568,3.858,3.836],[2.956,0.248,0.241],[0.971,0.203,0.199],[2.96,0.247,0.242],[9.863,0.935,0.906],[9.327,7.148,7.179],[0.661,0.421,0.417],[2.556,0.451,0.445],[6.277,0.511,0.441],[4.925,1.796,1.764],[10.7,2.639,2.679],[10.685,2.701,2.78],[0.931,0.578,0.592],[9.901,0.754,0.739],[8.919,0.671,0.676],[9.859,0.714,0.719],[18.674,0.993,0.966],[2.82,0.114,0.114],[2.019,0.11,0.113],[1.335,0.101,0.101]],"source":"sail-partitioned/results/c8g.4xlarge.json"}
,{"system":"Sail (Parquet)","date":"2025-10-09","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14779976446,"result":[[0.835,0.007,0.007],[0.417,0.025,0.025],[0.528,0.092,0.089],[0.959,0.094,0.089],[1.769,1.467,1.452],[1.81,1.207,1.222],[0.137,0.007,0.007],[0.213,0.029,0.029],[1.926,1.571,1.547],[2.192,1.622,1.583],[0.75,0.362,0.361],[0.85,0.397,0.396],[1.56,1.203,1.201],[3.242,1.998,2.003],[1.505,1.166,1.154],[1.993,1.576,1.579],[3.259,2.673,2.65],[3.216,2.674,2.772],[5.862,4.918,4.975],[0.479,0.087,0.088],[11.067,1.608,1.599],[11.326,1.876,1.869],[22.578,3.828,3.829],[57.228,33.02,16.29],[2.768,0.598,0.595],[0.886,0.459,0.456],[2.756,0.599,0.589],[9.739,2.21,2.25],[18.723,17.773,17.69],[1.249,0.999,1.004],[2.512,1.149,1.137],[5.97,1.246,1.185],[4.765,4.101,4.171],[11.748,6.496,6.598],[11.765,6.584,6.669],[2.082,1.68,1.728],[9.767,1.431,1.43],[9.097,1.645,1.662],[9.743,1.426,1.409],[18.697,2.738,2.78],[2.798,0.286,0.284],[1.957,0.256,0.255],[1.18,0.197,0.192]],"source":"sail/results/c6a.2xlarge.json"}
,{"system":"Sail (Parquet)","date":"2025-10-09","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["column-oriented"],"load_time":0,"data_size":14779976446,"result":[[0.36,0.007,0.006],[0.356,0.018,0.018],[0.365,0.055,0.051],[0.828,0.063,0.061],[1.027,0.825,0.836],[1.26,0.766,0.762],[0.128,0.007,0.007],[0.182,0.021,0.021],[1.178,0.885,0.887],[1.401,1.015,1.007],[0.574,0.208,0.208],[0.667,0.23,0.226],[1.111,0.831,0.821],[2.967,1.334,1.55],[1.152,0.836,0.835],[1.176,0.936,0.91],[2.771,1.705,1.72],[2.806,1.716,1.692],[5.287,3.332,3.373],[0.451,0.062,0.06],[9.625,1.605,1.62],[11.366,1.861,1.906],[22.23,4.022,4.063],[56.572,10.849,10.903],[2.733,0.407,0.405],[0.876,0.285,0.294],[2.724,0.403,0.399],[9.681,2.467,2.498],[10.364,9.441,9.387],[0.738,0.607,0.558],[2.411,0.735,0.761],[5.949,0.962,0.924],[4.68,3.362,3.438],[10.784,5.279,5.38],[10.771,5.351,5.352],[1.239,1.026,0.993],[9.769,1.543,1.532],[8.96,1.558,1.607],[9.754,1.544,1.572],[18.647,3.035,3.056],[2.785,0.202,0.203],[1.941,0.218,0.222],[1.164,0.147,0.147]],"source":"sail/results/c6a.4xlarge.json"}
@@ -363,6 +375,12 @@ const data = [
,{"system":"Snowflake","date":"2022-07-01","machine":"Snowflake: S","cluster_size":2,"comment":"","proprietary":"yes","tuned":"no","tags":["managed","column-oriented"],"load_time":2524,"data_size":12300000000,"result":[[0.186,0.060,0.062],[0.980,0.574,0.311],[0.977,0.554,0.426],[0.686,0.573,0.404],[1.386,1.384,1.349],[1.871,1.697,1.704],[0.052,0.059,0.227],[0.309,0.536,0.508],[1.768,1.631,1.635],[2.039,2.219,1.908],[0.807,0.647,0.587],[0.763,0.690,0.631],[1.403,1.586,1.404],[2.593,2.584,2.554],[1.670,1.538,1.653],[1.659,1.509,1.514],[2.875,2.990,2.998],[2.605,2.549,2.598],[6.120,5.894,5.766],[0.320,0.431,0.416],[2.406,1.703,1.609],[1.189,1.186,1.163],[2.104,1.441,1.370],[7.144,5.174,4.139],[0.839,0.659,0.641],[0.527,0.518,0.509],[0.633,0.621,0.695],[1.491,1.509,1.514],[4.848,4.485,4.571],[3.067,3.106,3.098],[1.521,1.224,1.236],[1.839,1.690,1.497],[5.692,5.751,6.087],[6.733,6.755,6.712],[6.722,6.709,6.676],[1.704,1.686,1.676],[0.203,0.231,0.218],[0.151,0.134,0.214],[0.140,0.156,0.163],[0.317,0.328,0.319],[0.166,0.133,0.141],[0.166,0.120,0.140],[0.120,0.119,0.126]],"source":"snowflake/results/s.json"}
,{"system":"Snowflake","date":"2022-07-01","machine":"Snowflake: XL","cluster_size":16,"comment":"","proprietary":"yes","tuned":"no","tags":["managed","column-oriented"],"load_time":2524,"data_size":12300000000,"result":[[0.071,0.053,0.057],[0.998,0.610,0.240],[0.420,1.138,1.051],[0.653,0.264,0.178],[0.352,0.312,0.349],[1.126,0.431,0.420],[0.067,0.057,0.054],[0.225,0.217,0.200],[0.617,0.366,0.371],[1.006,0.541,0.498],[0.463,0.425,0.293],[0.431,0.360,0.339],[0.392,0.371,0.386],[0.588,0.581,0.590],[0.634,0.414,0.400],[0.368,0.410,0.388],[0.594,0.639,0.663],[0.616,0.581,0.569],[1.092,0.933,0.901],[0.493,0.213,0.160],[0.886,0.480,0.442],[0.448,0.337,0.399],[0.840,0.572,0.505],[2.251,1.230,0.959],[0.295,0.253,0.241],[0.214,0.239,0.278],[0.261,0.232,0.314],[0.422,0.429,0.403],[0.892,0.934,0.883],[1.041,1.017,1.009],[0.715,0.442,0.363],[0.845,0.413,0.461],[1.101,1.085,1.102],[1.294,1.272,1.339],[1.839,1.327,1.241],[0.439,0.399,0.393],[0.199,0.211,0.190],[0.157,0.143,0.140],[0.145,0.157,0.141],[0.331,0.291,0.333],[0.173,0.214,0.138],[0.189,0.150,0.159],[0.135,0.149,0.138]],"source":"snowflake/results/xl.json"}
,{"system":"Snowflake","date":"2022-07-01","machine":"Snowflake: XS","cluster_size":1,"comment":"","proprietary":"yes","tuned":"no","tags":["managed","column-oriented"],"load_time":2524,"data_size":12300000000,"result":[[0.169,0.055,0.056],[1.184,0.582,0.386],[1.350,0.560,0.568],[1.270,0.554,0.538],[2.516,2.564,2.506],[2.935,2.649,2.670],[0.052,0.050,0.064],[0.383,0.387,0.397],[3.249,2.993,3.014],[3.589,3.627,3.887],[1.243,0.986,0.966],[1.325,1.080,1.073],[2.038,2.046,2.035],[3.738,3.626,3.718],[2.318,2.159,2.176],[2.733,2.637,2.668],[5.607,5.683,5.667],[3.978,3.923,3.879],[10.085,9.871,9.844],[0.450,0.375,0.469],[5.474,3.103,3.060],[2.012,1.982,1.971],[3.365,2.471,2.501],[11.960,10.619,9.518],[1.074,1.059,1.026],[0.856,0.846,0.879],[1.100,1.085,1.083],[3.057,3.228,3.117],[9.406,9.019,9.158],[6.196,6.243,6.911],[2.906,2.343,2.017],[2.954,2.666,2.565],[9.459,9.565,9.557],[9.555,9.529,9.368],[9.409,9.185,9.294],[2.796,2.880,2.685],[0.299,0.249,0.262],[0.156,0.145,0.180],[0.147,0.146,0.160],[0.371,0.357,0.356],[0.166,0.133,0.155],[0.218,0.140,0.135],[0.140,0.152,0.158]],"source":"snowflake/results/xs.json"}
+,{"system":"Spark (Auron)","date":"2025-10-15","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[58.147,45.917,44.68],[3.78,1.588,1.364],[4.284,1.818,1.583],[4.214,1.716,1.468],[7.226,4.955,4.095],[6.292,3.798,3.535],[5.681,3.129,2.906],[3.862,1.583,1.388],[8.208,5.713,5.266],[11.706,8.854,8.489],[4.775,2.156,1.855],[4.942,2.29,2.017],[6.35,3.741,3.514],[9.479,7.06,7.575],[6.727,4.109,3.773],[8.197,5.7,5.321],[11.766,9.126,9.003],[8.34,5.973,5.718],[20.273,17.703,16.344],[3.662,1.476,1.365],[11.386,3.552,3.304],[13.341,4.136,3.877],[23.938,5.844,5.524],[58.805,46.323,44.78],[5.744,2.92,2.58],[4.617,2.276,2.007],[5.682,2.862,2.738],[11.632,5.297,4.882],[24.069,20.545,20.259],[11.786,8.8,8.561],[6.585,3.875,3.582],[9.556,5.403,5.068],[24.313,21.462,21.299],[16.352,12.018,11.683],[16.851,11.87,11.516],[8.102,5.429,5.111],[4.132,1.765,1.553],[3.973,1.594,1.486],[4.281,1.788,1.476],[5.941,2.869,2.463],[4.419,1.743,1.506],[4.238,1.667,1.376],[4.319,1.698,1.43]],"source":"spark-auron/results/c6a.2xlarge.json"}
+,{"system":"Spark (Auron)","date":"2025-10-15","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[57.95,11.492,11.457],[3.21,1.092,0.92],[3.348,1.173,1.005],[3.288,1.112,1.022],[5.213,2.968,2.781],[4.752,2.557,2.327],[4.155,1.767,1.653],[3.378,1.108,0.927],[6.092,3.817,3.519],[7.945,5.662,5.39],[3.942,1.546,1.294],[4.011,1.649,1.369],[4.834,2.557,2.302],[6.588,4.176,3.878],[5.164,2.824,2.572],[5.615,3.412,3.134],[8.193,5.884,5.59],[5.895,3.731,3.478],[13.321,10.407,10.284],[3.13,1.059,1.03],[11.402,2.634,2.465],[13.181,2.977,2.783],[24.005,4.626,4.435],[58.625,17.595,17.347],[4.405,1.754,1.684],[3.605,1.535,1.351],[4.352,1.854,1.771],[11.816,3.78,3.534],[14.537,11.357,11.106],[11.147,8.578,8.39],[5.114,2.673,2.471],[8.483,3.056,2.797],[16.698,14.124,14.025],[14.732,9.005,8.593],[14.801,8.886,8.714],[5.66,3.353,3.103],[3.589,1.232,1.078],[3.42,1.102,0.963],[3.745,1.235,1.045],[5.222,2.353,2.083],[3.91,1.276,1.088],[3.727,1.126,1.038],[3.756,1.22,1.031]],"source":"spark-auron/results/c6a.4xlarge.json"}
+,{"system":"Spark (Auron)","date":"2025-10-16","machine":"c6a.large","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[82.112,78.673,78.263],[9.207,5.154,4.582],[10.254,6.34,5.5],[10.524,5.919,5.262],[20.023,15.39,14.152],[21.696,14.237,13.105],[16.612,11.33,10.756],[10.041,5.681,4.763],[22.896,17.96,16.811],[34.947,29.701,28.602],[12.31,7.5,6.51],[12.952,8.028,6.892],[21.513,16.942,14.904],[36.368,29.819,29.818],[21.777,17.725,15.727],[23.702,18.537,18.009],[37.063,31.309,29.986],[24.134,18.42,17.547],[68.087,60.277,61.653],[9.385,4.706,4.724],[19.917,12.583,11.728],[22.729,15.157,13.966],[34.339,26.264,27.813],[102.081,95.868,94.019],[17.413,10.05,9.253],[13.75,8.45,7.468],[16.052,10.758,9.682],[24.85,17.201,16.297],[84.127,76.615,77.281],[36.997,31.816,30.645],[22.694,15.746,14.702],[25.961,19.053,17.989],[84.071,77.628,76.567],[69.31,61.847,60.98],[65.929,60.132,60.4],[22.115,17.563,16.639],[11.013,5.887,4.945],[10.154,5.675,4.668],[10.201,5.709,4.94],[13.111,8.155,7.026],[10.34,6.111,4.992],[10.234,5.753,4.651],[10.169,6.084,4.994]],"source":"spark-auron/results/c6a.large.json"}
+,{"system":"Spark (Auron)","date":"2025-10-16","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[75.585,38.301,38.048],[39.201,37.094,37.646],[39.502,37.295,35.012],[39.454,36.901,35.406],[50.535,47.766,46.557],[77.835,75.399,73.981],[44.448,39.91,36.836],[38.729,37.46,35.939],[81.341,75.246,74.077],[82.033,73.671,74.671],[39.896,35.735,36.352],[40.217,38.078,36.499],[81.086,73.669,72.985],[113.514,111.96,112.165],[74.705,73.781,74.067],[50.934,46.38,47],[82.543,76.633,76.459],[41.262,40.882,36.326],[81.797,76.921,77.889],[13.317,14.833,10.793],[39.798,35.889,35.928],[39.659,36.078,37.112],[43.649,37.584,37.285],[77.906,40.807,40.539],[40.531,35.889,37.18],[39.227,35.294,35.756],[40.339,36.783,35.342],[39.546,37.271,35.839],[83.408,79.416,77.833],[41.528,36.724,36.976],[44.324,41.545,40.953],[79.989,74.188,73.242],[81.781,75.443,74.846],[82.856,77.742,76.08],[83.197,78.911,76.303],[51.941,48.019,46.468],[40.635,36.332,38.299],[39.538,36.796,35.579],[39.968,36.98,36.524],[44.931,40.136,41.553],[40.499,37.395,37.654],[39.291,37.156,35.503],[41.102,36.042,36.827]],"source":"spark-auron/results/c6a.metal.json"}
+,{"system":"Spark (Auron)","date":"2025-10-16","machine":"c6a.xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[65.457,52.707,53.013],[5.478,2.799,2.254],[6.286,3.144,2.751],[5.824,3.076,2.686],[11.989,8.605,7.837],[10.663,7.857,6.626],[9.222,5.6,5.372],[5.814,2.851,2.356],[12.8,9.755,9.08],[19.137,15.381,14.621],[7.244,3.99,3.315],[7.618,4.241,3.556],[11.329,8.127,7.649],[18.21,14.183,13.46],[12.17,8.654,8.234],[12.906,9.63,9.129],[20.398,15.945,15.457],[13.077,9.932,9.443],[35.112,30.755,30.445],[5.747,2.588,2.443],[11.952,6.57,5.919],[13.463,7.158,6.78],[24.258,10.725,10.215],[59.173,50.414,50.095],[8.854,4.925,4.755],[6.901,4.183,3.787],[9.07,5.237,4.961],[13.334,9.261,8.735],[43.633,38.08,37.865],[19.686,15.689,15.172],[11.797,7.945,7.404],[13.691,9.653,9.24],[42.979,40.129,38.605],[27.019,21.829,22.606],[26.506,22.02,22.18],[13.186,9.78,9.511],[6.134,3.103,2.421],[5.873,2.903,2.346],[6.399,3.055,2.395],[8.188,4.49,3.745],[6.573,3.124,2.55],[6.299,2.948,2.396],[6.3,3.07,2.399]],"source":"spark-auron/results/c6a.xlarge.json"}
+,{"system":"Spark (Auron)","date":"2025-10-16","machine":"c7a.metal-48xl","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[72.917,37.208,36.073],[42.566,37.155,36.966],[40.477,37.208,35.972],[40.879,37.252,36.44],[51.133,46.912,46.947],[84.434,77.317,79.121],[41.287,38.446,37.57],[39.734,36.946,36.284],[83.13,75.294,76.694],[81.958,77.498,80.801],[43.502,38.235,36.93],[42.951,37.495,38.884],[87.197,76.613,76.353],[127.117,119.968,117.481],[81.298,83.37,83.211],[50.191,48.348,46.665],[82.702,78.844,77.609],[42.218,38.067,37.652],[87.706,82.183,79.463],[10.136,13.682,15.128],[40.315,37.343,37.033],[42.428,37.615,36.085],[45.01,37.916,38.022],[74.679,39.401,37.675],[41.267,38.353,38.075],[41.171,36.616,36.421],[40.445,37.23,36.348],[40.519,39.133,36.81],[88.596,78.613,78.634],[42.973,38.295,37.636],[46.782,42.805,41.347],[78.699,77.344,76.179],[84.487,80.711,82.391],[87.69,80.691,80.081],[82.491,81.05,79.722],[50.891,56.102,47.895],[43.132,38.194,38.858],[40.887,36.817,37.732],[40.749,36.925,37.365],[45.396,40.952,40.577],[41.626,37.999,37.025],[40.868,38.019,36.439],[43.151,37.532,36.32]],"source":"spark-auron/results/c7a.metal-48xl.json"}
,{"system":"Spark (Comet)","date":"2025-08-15","machine":"c6a.2xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[6.07,3.499,3.22],[6.375,3.384,3.054],[6.863,3.656,3.459],[6.896,4.042,3.226],[8.011,4.853,4.358],[8.58,5.123,4.804],[7.129,4.032,3.922],[6.578,3.743,3.198],[9.141,4.968,4.722],[11.746,7.408,6.972],[8.257,3.923,3.912],[8.496,4.734,4.225],[8.553,5.344,4.891],[13.018,8.533,8.207],[9.096,5.335,5.11],[8.511,5.212,4.706],[11.02,7.242,7.192],[9.783,6.471,6.28],[25.269,20.455,20.252],[6.453,3.867,3.578],[11.853,5.251,4.992],[13.776,5.604,5.159],[25.439,7.676,7.362],[58.816,47.919,47.812],[7.52,4.084,4.012],[7.035,3.927,3.703],[7.645,4.15,3.998],[12.216,5.726,5.492],[37.439,32.433,31.996],[11.211,7.899,7.948],[8.989,5.126,4.934],[9.718,5.528,5.304],[16.879,13.137,12.894],[17.675,12.341,11.8],[18.086,12.288,11.743],[9.135,5.781,5.287],[12.101,4.946,4.801],[11.238,4.874,4.762],[12.549,5.144,4.872],[22.121,7.737,7.256],[7.881,4.118,3.728],[7.838,4.278,3.779],[7.944,4.339,4.003]],"source":"spark-comet/results/c6a.2xlarge.json"}
,{"system":"Spark (Comet)","date":"2025-08-15","machine":"c6a.4xlarge","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[4.407,1.961,1.859],[4.634,1.965,1.756],[4.865,1.999,1.856],[4.873,1.92,1.779],[5.692,2.805,2.407],[6.195,3.137,2.727],[5.012,2.327,2.165],[4.855,1.972,2.054],[6.401,3.129,2.927],[8.191,4.604,4.256],[5.886,2.471,2.23],[6.005,2.567,2.307],[6.147,3.141,2.836],[9.15,5.178,5.063],[6.063,3.122,2.931],[5.99,3.293,2.896],[7.412,4.419,4.184],[6.668,3.612,3.504],[16.61,12.244,12.007],[4.694,2.196,2.089],[11.882,3.178,2.868],[13.792,3.561,3.301],[25.284,5.502,5.439],[58.863,14.033,14.132],[5.251,2.334,2.238],[5.031,2.287,1.989],[5.265,2.359,2.295],[12.289,3.681,3.694],[21.839,17.488,17.323],[7.24,4.38,4.209],[6.434,3.091,2.888],[8.932,3.63,3.264],[11.618,8.89,8.346],[14.253,8.292,7.955],[14.244,7.855,7.664],[6.349,3.459,3.041],[12.271,3.265,3.03],[11.459,3.096,2.894],[12.462,3.381,3.184],[22.029,5.216,5.047],[5.867,2.537,2.279],[5.907,2.393,2.131],[5.837,2.32,2.093]],"source":"spark-comet/results/c6a.4xlarge.json"}
,{"system":"Spark (Comet)","date":"2025-08-15","machine":"c6a.metal","cluster_size":1,"proprietary":"no","tuned":"no","tags":["Java","Rust","column-oriented","Spark derivative"],"load_time":0,"data_size":14779976446,"result":[[4.985,0.847,0.73],[5.133,0.901,0.669],[4.92,0.909,1.275],[5.347,1.266,0.814],[5.671,1.097,0.992],[6.747,1.211,1.001],[5.15,0.913,0.855],[5.152,1.198,1.697],[7.219,2.101,2.009],[9.293,2.677,1.583],[6.437,1.248,0.997],[6.459,1.457,1.13],[6.562,1.587,1.187],[9.864,1.727,1.79],[6.14,1.413,1.153],[6.221,1.525,1.159],[7.268,1.499,1.263],[6.297,1.177,0.956],[11.454,3.122,3.6],[3.783,1.228,0.985],[14.027,1.608,0.975],[15.832,1.994,0.976],[26.989,2.857,1.866],[61.562,6.949,5.912],[6.66,1.091,0.899],[5.18,0.984,0.733],[6.606,0.894,0.962],[14.752,2.319,1.754],[16.858,6.733,5.775],[6.342,1.717,1.409],[6.896,2.202,1.547],[11.413,2.398,2.212],[10.93,3.664,2.666],[15.874,2.703,2.323],[15.593,2.44,2.272],[6.668,1.689,1.524],[14.825,2.451,1.287],[13.465,1.594,1.012],[14.644,1.764,1.255],[24.763,3.033,1.904],[7.023,1.352,0.895],[6.687,1.201,1.111],[6.11,1.232,0.9]],"source":"spark-comet/results/c6a.metal.json"}
diff --git a/hyper/results/c6a.2xlarge.json b/hyper/results/c6a.2xlarge.json
index 13e3d4b3b..195bbe9a8 100644
--- a/hyper/results/c6a.2xlarge.json
+++ b/hyper/results/c6a.2xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "Salesforce Hyper",
- "date": "2025-07-10",
+ "system": "Salesforce Hyper",
+ "date": "2025-10-16",
"machine": "c6a.2xlarge",
"cluster_size": 1,
- "proprietary": "yes",
- "tuned": "no",
- "tags": ["C++","column-oriented"],
- "load_time": 686,
+ "proprietary": "yes",
+ "tuned": "no",
+ "tags": ["C++","column-oriented"],
+ "load_time": 649,
"data_size": 18959040512,
"result": [
- [0.038, 0.01, 0.01],
- [0.157, 0.017, 0.017],
- [0.478, 0.057, 0.057],
- [1.093, 0.056, 0.056],
- [1.121, 0.875, 0.885],
- [2.195, 0.341, 0.34],
- [0.133, 0.002, 0.002],
- [0.19, 0.018, 0.017],
- [2.413, 1.24, 1.244],
- [3.906, 1.335, 1.333],
- [1.19, 0.09, 0.089],
- [1.209, 0.096, 0.095],
- [2.207, 0.55, 0.561],
- [5.262, 1.854, 1.883],
- [2.263, 0.62, 0.624],
- [1.666, 1.067, 1.069],
- [5.019, 1.61, 1.62],
- [4.592, 1.444, 1.447],
- [9.284, 3.37, 3.439],
- [0.21, 0.002, 0.002],
- [14.784, 0.643, 0.643],
- [19.204, 0.641, 0.657],
- [17.137, 0.428, 0.425],
- [64.173, 29.257, 13.603],
- [5.485, 0.104, 0.105],
- [1.984, 0.104, 0.104],
- [5.488, 0.105, 0.105],
- [17.736, 0.936, 1.138],
- [12.672, 4.397, 4.41],
- [1.15, 0.971, 0.97],
- [5.316, 0.544, 0.534],
- [8.832, 0.847, 0.843],
- [9.829, 6.197, 6.216],
- [15.53, 2.303, 2.312],
- [18.027, 2.505, 2.301],
- [1.159, 0.921, 0.911],
- [0.194, 0.017, 0.017],
- [0.166, 0.006, 0.005],
- [0.177, 0.004, 0.003],
- [0.28, 0.031, 0.032],
- [0.279, 0.002, 0.002],
- [0.28, 0.003, 0.003],
- [0.165, 0.005, 0.004]
+ [0.049, 0.011, 0.011],
+ [0.17, 0.019, 0.019],
+ [0.486, 0.058, 0.058],
+ [1.248, 0.055, 0.055],
+ [1.145, 0.9, 0.899],
+ [2.203, 0.341, 0.344],
+ [0.148, 0.001, 0.001],
+ [0.169, 0.02, 0.019],
+ [2.473, 1.262, 1.226],
+ [3.913, 1.434, 1.355],
+ [1.195, 0.087, 0.086],
+ [1.201, 0.093, 0.092],
+ [2.178, 0.565, 0.573],
+ [5.371, 1.871, 1.87],
+ [2.233, 0.632, 0.63],
+ [1.84, 1.115, 1.101],
+ [4.98, 1.642, 1.663],
+ [4.72, 1.436, 1.452],
+ [9.445, 3.458, 3.524],
+ [0.239, 0.002, 0.001],
+ [14.698, 0.637, 0.639],
+ [16.616, 0.632, 0.632],
+ [17.021, 0.42, 0.418],
+ [64.069, 27.022, 16.026],
+ [5.455, 0.108, 0.106],
+ [1.949, 0.107, 0.107],
+ [5.456, 0.109, 0.109],
+ [15.659, 0.965, 0.965],
+ [12.59, 4.394, 4.405],
+ [1.11, 0.931, 0.932],
+ [5.402, 0.537, 0.536],
+ [8.939, 0.843, 0.88],
+ [10.029, 6.223, 6.216],
+ [15.445, 2.339, 2.317],
+ [15.868, 2.328, 2.316],
+ [1.292, 0.956, 0.955],
+ [0.218, 0.018, 0.016],
+ [0.176, 0.006, 0.005],
+ [0.188, 0.004, 0.003],
+ [0.291, 0.033, 0.031],
+ [0.337, 0.003, 0.002],
+ [0.295, 0.003, 0.003],
+ [0.172, 0.005, 0.004]
]
-}
\ No newline at end of file
+}
+
diff --git a/hyper/results/c6a.4xlarge.json b/hyper/results/c6a.4xlarge.json
index 5ad81de61..2543698a8 100644
--- a/hyper/results/c6a.4xlarge.json
+++ b/hyper/results/c6a.4xlarge.json
@@ -1,56 +1,57 @@
{
- "system": "Salesforce Hyper",
- "date": "2025-07-10",
+ "system": "Salesforce Hyper",
+ "date": "2025-10-16",
"machine": "c6a.4xlarge",
"cluster_size": 1,
- "proprietary": "yes",
- "tuned": "no",
- "tags": ["C++","column-oriented"],
- "load_time": 687,
+ "proprietary": "yes",
+ "tuned": "no",
+ "tags": ["C++","column-oriented"],
+ "load_time": 673,
"data_size": 18959040512,
"result": [
- [0.036, 0.006, 0.006],
- [0.096, 0.009, 0.009],
- [0.476, 0.03, 0.029],
- [1.094, 0.03, 0.029],
- [0.984, 0.581, 0.564],
- [2.117, 0.16, 0.16],
- [0.09, 0.003, 0.003],
- [0.106, 0.01, 0.009],
- [2.179, 0.795, 0.804],
- [3.702, 0.836, 0.834],
- [1.18, 0.048, 0.048],
- [1.185, 0.051, 0.051],
- [2.162, 0.298, 0.3],
- [4.773, 0.956, 0.958],
- [2.169, 0.298, 0.3],
- [1.487, 0.688, 0.688],
- [4.648, 1.011, 1.028],
- [4.428, 0.896, 0.883],
- [8.694, 2.079, 2.1],
- [0.147, 0.003, 0.003],
- [17.196, 0.419, 0.395],
- [16.212, 0.396, 0.399],
- [17.853, 0.304, 0.335],
- [55.378, 0.523, 0.511],
- [5.488, 0.06, 0.059],
- [1.984, 0.057, 0.057],
- [5.49, 0.063, 0.062],
- [15.914, 0.677, 0.696],
- [12.657, 2.297, 2.309],
- [0.619, 0.488, 0.488],
- [4.974, 0.278, 0.279],
- [8.976, 0.522, 0.518],
- [8.216, 3.848, 3.808],
- [17.794, 1.449, 1.469],
- [15.345, 1.463, 1.479],
- [0.958, 0.638, 0.636],
- [0.131, 0.012, 0.011],
- [0.116, 0.005, 0.004],
- [0.115, 0.004, 0.004],
- [0.236, 0.022, 0.022],
- [0.171, 0.004, 0.003],
- [0.17, 0.004, 0.004],
- [0.117, 0.005, 0.004]
+ [0.041, 0.006, 0.006],
+ [0.114, 0.01, 0.01],
+ [0.481, 0.03, 0.03],
+ [1.419, 0.03, 0.029],
+ [1.133, 0.562, 0.569],
+ [2.118, 0.161, 0.159],
+ [0.091, 0.001, 0.001],
+ [0.102, 0.011, 0.01],
+ [2.246, 0.806, 0.781],
+ [3.695, 0.839, 0.832],
+ [1.17, 0.047, 0.047],
+ [1.301, 0.05, 0.049],
+ [2.187, 0.291, 0.293],
+ [4.85, 0.958, 0.963],
+ [2.131, 0.301, 0.302],
+ [1.641, 0.71, 0.713],
+ [4.663, 1.01, 1.003],
+ [4.535, 0.9, 0.885],
+ [8.813, 2.062, 2.076],
+ [0.144, 0.002, 0.001],
+ [15.137, 0.378, 0.378],
+ [16.307, 0.379, 0.378],
+ [17.195, 0.252, 0.252],
+ [54.612, 0.493, 0.485],
+ [5.453, 0.058, 0.057],
+ [1.945, 0.059, 0.058],
+ [5.467, 0.059, 0.058],
+ [15.383, 0.529, 0.527],
+ [12.555, 2.275, 2.277],
+ [0.611, 0.47, 0.47],
+ [5.322, 0.275, 0.274],
+ [8.731, 0.461, 0.461],
+ [8.217, 3.694, 3.679],
+ [15.608, 1.414, 1.42],
+ [15.378, 1.409, 1.423],
+ [1.135, 0.631, 0.632],
+ [0.31, 0.012, 0.011],
+ [0.303, 0.005, 0.004],
+ [0.235, 0.004, 0.003],
+ [0.235, 0.022, 0.021],
+ [0.252, 0.002, 0.001],
+ [0.181, 0.003, 0.002],
+ [0.119, 0.004, 0.004]
]
-}
\ No newline at end of file
+}
+
diff --git a/hyper/results/c6a.large.json b/hyper/results/c6a.large.json
new file mode 100644
index 000000000..06a4abef9
--- /dev/null
+++ b/hyper/results/c6a.large.json
@@ -0,0 +1,57 @@
+{
+ "system": "Salesforce Hyper",
+ "date": "2025-10-16",
+ "machine": "c6a.large",
+ "cluster_size": 1,
+ "proprietary": "yes",
+ "tuned": "no",
+ "tags": ["C++","column-oriented"],
+ "load_time": 781,
+ "data_size": 18959040512,
+ "result": [
+ [0.077, 0.042, 0.043],
+ [0.534, 0.073, 0.073],
+ [1.443, 0.226, 0.226],
+ [1.967, 0.219, 0.219],
+ [3.502, 2.581, 2.632],
+ [2.824, 1.187, 1.19],
+ [0.463, 0.002, 0.002],
+ [0.521, 0.075, 0.075],
+ [5.251, 3.238, 3.2],
+ [6.6, 3.78, 3.617],
+ [2.771, 0.36, 0.358],
+ [2.882, 0.363, 0.368],
+ [4.87, 1.741, 1.755],
+ [10.992, 6.142, 6.165],
+ [5.07, 1.848, 1.855],
+ [4.858, 3.142, 3.052],
+ [10.4, 5.469, 4.927],
+ [9.671, 4.806, 4.398],
+ [114.993, 120.63, 120.087],
+ [0.816, 0.004, 0.004],
+ [20.329, 22.671, 23.913],
+ [22.507, 24.243, 25.628],
+ [23.602, 20.991, 20.593],
+ [74.987, 70.269, 68.871],
+ [6.249, 0.399, 0.396],
+ [3.515, 0.407, 0.401],
+ [6.22, 0.403, 0.403],
+ [22.288, 25.39, 25.348],
+ [33.542, 31.051, 30.708],
+ [4.179, 3.715, 3.786],
+ [6.977, 1.712, 1.732],
+ [10.834, 4.453, 2.885],
+ [172.245, 175.589, 176.369],
+ [478.941, 461.72, 470.315],
+ [479.096, 456.128, 456.587],
+ [3.67, 2.349, 2.345],
+ [0.76, 0.056, 0.05],
+ [0.563, 0.019, 0.018],
+ [0.569, 0.008, 0.007],
+ [1.003, 0.104, 0.1],
+ [0.998, 0.004, 0.004],
+ [1.014, 0.006, 0.006],
+ [0.524, 0.012, 0.012]
+]
+}
+
diff --git a/hyper/results/c6a.metal.json b/hyper/results/c6a.metal.json
index e596e7a88..324817cad 100644
--- a/hyper/results/c6a.metal.json
+++ b/hyper/results/c6a.metal.json
@@ -1,58 +1,57 @@
{
"system": "Salesforce Hyper",
- "date": "2024-01-17",
+ "date": "2025-10-15",
"machine": "c6a.metal",
"cluster_size": 1,
"proprietary": "yes",
"tuned": "no",
-
- "tags": ["C++", "column-oriented"],
-
- "load_time": 413,
+ "tags": ["C++","column-oriented"],
+ "load_time": 441,
"data_size": 18959040512,
"result": [
- [0.027,0.018,0.005],
- [0.075,0.022,0.011],
- [0.477,0.016,0.015],
- [1.102,0.026,0.025],
- [0.672,0.092,0.083],
- [2.029,0.056,0.060],
- [0.076,0.015,0.020],
- [0.070,0.011,0.016],
- [1.865,0.148,0.149],
- [3.330,0.167,0.172],
- [1.174,0.029,0.052],
- [1.185,0.021,0.023],
- [2.043,0.068,0.068],
- [4.231,0.242,0.240],
- [2.045,0.074,0.075],
- [1.254,0.174,0.164],
- [4.217,0.208,0.208],
- [4.160,0.147,0.153],
- [8.140,0.498,0.514],
- [0.123,0.014,0.013],
- [14.915,0.092,0.078],
- [16.253,0.072,0.066],
- [17.236,0.057,0.058],
- [41.629,0.091,0.083],
- [5.490,0.016,0.019],
- [1.989,0.014,0.015],
- [5.492,0.015,0.016],
- [15.379,0.095,0.092],
- [12.728,0.367,0.383],
- [0.229,0.054,0.054],
- [4.880,0.067,0.066],
- [8.411,0.093,0.097],
- [6.423,0.757,0.761],
- [15.299,0.302,0.310],
- [14.980,0.266,0.269],
- [0.757,0.127,0.122],
- [0.117,0.024,0.022],
- [0.105,0.030,0.014],
- [0.107,0.016,0.025],
- [0.157,0.037,0.040],
- [0.142,0.018,0.018],
- [0.142,0.017,0.017],
- [0.089,0.017,0.017]
- ]
+ [0.031, 0.007, 0.006],
+ [0.063, 0.005, 0.005],
+ [0.475, 0.006, 0.006],
+ [1.671, 0.01, 0.009],
+ [1.119, 0.131, 0.126],
+ [2.041, 0.059, 0.061],
+ [0.062, 0.002, 0.001],
+ [0.077, 0.013, 0.018],
+ [1.926, 0.155, 0.15],
+ [3.38, 0.154, 0.162],
+ [1.159, 0.034, 0.018],
+ [1.437, 0.02, 0.019],
+ [2.324, 0.076, 0.078],
+ [4.441, 0.268, 0.272],
+ [2.01, 0.084, 0.079],
+ [1.396, 0.15, 0.149],
+ [4.328, 0.197, 0.18],
+ [4.27, 0.137, 0.145],
+ [8.513, 0.678, 0.668],
+ [0.087, 0.001, 0.001],
+ [14.881, 0.096, 0.073],
+ [16.118, 0.096, 0.083],
+ [17.022, 0.072, 0.069],
+ [41.498, 0.092, 0.09],
+ [5.454, 0.026, 0.022],
+ [2.131, 0.019, 0.017],
+ [5.738, 0.017, 0.017],
+ [15.325, 0.144, 0.108],
+ [12.618, 0.38, 0.388],
+ [0.195, 0.056, 0.055],
+ [5.198, 0.072, 0.072],
+ [8.517, 0.112, 0.111],
+ [6.689, 0.847, 0.85],
+ [14.962, 0.394, 0.397],
+ [14.926, 0.31, 0.313],
+ [0.944, 0.137, 0.125],
+ [0.102, 0.01, 0.01],
+ [0.079, 0.005, 0.004],
+ [0.091, 0.004, 0.003],
+ [0.125, 0.021, 0.021],
+ [0.114, 0.006, 0.005],
+ [0.385, 0.004, 0.004],
+ [0.074, 0.005, 0.005]
+]
}
+
diff --git a/hyper/results/c6a.xlarge.json b/hyper/results/c6a.xlarge.json
index 02f3caf1e..17c75dd62 100644
--- a/hyper/results/c6a.xlarge.json
+++ b/hyper/results/c6a.xlarge.json
@@ -1,57 +1,57 @@
{
"system": "Salesforce Hyper",
- "date": "2025-08-31",
+ "date": "2025-10-16",
"machine": "c6a.xlarge",
"cluster_size": 1,
"proprietary": "yes",
"tuned": "no",
"tags": ["C++","column-oriented"],
- "load_time": 661,
+ "load_time": 639,
"data_size": 18959040512,
"result": [
- [0.054, 0.021, 0.021],
- [0.299, 0.037, 0.036],
- [0.753, 0.114, 0.114],
- [1.101, 0.108, 0.108],
- [1.872, 1.427, 1.43],
- [2.309, 0.667, 0.68],
- [0.256, 0.002, 0.001],
- [0.293, 0.038, 0.037],
- [2.862, 2.07, 1.972],
- [4.243, 2.111, 2.127],
- [1.4, 0.168, 0.167],
- [1.447, 0.178, 0.172],
- [2.458, 0.993, 1.074],
- [6.207, 3.38, 3.382],
- [2.547, 1.034, 1.045],
- [2.468, 1.821, 1.801],
- [5.649, 2.798, 2.984],
- [5.001, 2.466, 2.484],
- [10.603, 6.097, 6.08],
- [0.435, 0.002, 0.002],
- [16.277, 1.508, 1.165],
- [20.091, 1.141, 1.129],
- [22.119, 0.739, 0.737],
- [72.69, 55, 43.277],
- [5.486, 0.205, 0.205],
- [1.986, 0.204, 0.204],
- [5.514, 0.206, 0.205],
- [17.741, 1.821, 1.823],
- [15.248, 8.727, 8.815],
- [2.109, 1.895, 1.856],
- [5.214, 0.929, 0.933],
- [9.177, 1.461, 1.445],
- [154.67, 155.619, 151.901],
- [19.148, 4.246, 4.176],
- [17.437, 4.307, 4.142],
- [2.028, 1.533, 1.528],
- [0.39, 0.029, 0.027],
+ [0.058, 0.021, 0.021],
+ [0.282, 0.037, 0.037],
+ [0.729, 0.114, 0.114],
+ [1.249, 0.108, 0.109],
+ [1.887, 1.444, 1.452],
+ [2.314, 0.674, 0.666],
+ [0.249, 0.001, 0.001],
+ [0.283, 0.038, 0.038],
+ [2.924, 2.11, 2.081],
+ [4.347, 2.29, 2.246],
+ [1.386, 0.173, 0.17],
+ [1.443, 0.185, 0.189],
+ [2.478, 1.013, 1.018],
+ [6.278, 3.369, 3.371],
+ [2.571, 1.075, 1.062],
+ [2.505, 1.845, 1.758],
+ [5.414, 2.852, 2.85],
+ [5.305, 2.487, 2.546],
+ [10.647, 6.134, 6.095],
+ [0.428, 0.003, 0.002],
+ [15.286, 1.154, 1.149],
+ [17.591, 1.156, 1.146],
+ [19.608, 0.762, 0.76],
+ [72.316, 51.118, 42.771],
+ [5.462, 0.201, 0.199],
+ [1.954, 0.205, 0.206],
+ [5.465, 0.205, 0.205],
+ [15.819, 1.824, 1.825],
+ [15.249, 8.738, 8.74],
+ [2.133, 1.914, 1.858],
+ [5.319, 0.938, 0.935],
+ [9.225, 1.438, 1.447],
+ [148.899, 151.44, 155.5],
+ [16.889, 4.356, 4.12],
+ [17.113, 4.192, 4.261],
+ [2.053, 1.523, 1.533],
+ [0.387, 0.027, 0.027],
[0.298, 0.01, 0.009],
- [0.308, 0.005, 0.004],
- [0.523, 0.056, 0.055],
- [0.523, 0.003, 0.002],
- [0.53, 0.004, 0.003],
- [0.287, 0.007, 0.007]
+ [0.31, 0.005, 0.004],
+ [0.523, 0.056, 0.053],
+ [0.526, 0.003, 0.002],
+ [0.532, 0.004, 0.004],
+ [0.288, 0.007, 0.007]
]
}
diff --git a/hyper/results/c7a.metal-48xl.json b/hyper/results/c7a.metal-48xl.json
index 6894dcc02..1d03fc2d6 100644
--- a/hyper/results/c7a.metal-48xl.json
+++ b/hyper/results/c7a.metal-48xl.json
@@ -1,56 +1,57 @@
{
- "system": "Salesforce Hyper",
- "date": "2025-08-30",
+ "system": "Salesforce Hyper",
+ "date": "2025-10-15",
"machine": "c7a.metal-48xl",
"cluster_size": 1,
- "proprietary": "yes",
- "tuned": "no",
- "tags": ["C++","column-oriented"],
- "load_time": 368,
+ "proprietary": "yes",
+ "tuned": "no",
+ "tags": ["C++","column-oriented"],
+ "load_time": 387,
"data_size": 18959040512,
"result": [
- [0.025, 0.004, 0.005],
- [0.091, 0.006, 0.009],
- [0.476, 0.006, 0.006],
- [1.432, 0.006, 0.006],
- [0.953, 0.075, 0.07],
- [2.09, 0.036, 0.038],
- [0.059, 0.001, 0.002],
- [0.058, 0.011, 0.009],
- [1.823, 0.115, 0.118],
- [3.273, 0.12, 0.123],
- [1.168, 0.016, 0.014],
- [1.452, 0.015, 0.014],
- [2.298, 0.046, 0.045],
- [4.189, 0.136, 0.129],
- [2.043, 0.052, 0.052],
- [1.245, 0.107, 0.132],
- [4.18, 0.145, 0.139],
- [4.136, 0.113, 0.11],
- [8.186, 0.52, 0.521],
- [0.115, 0.002, 0.001],
- [14.891, 0.057, 0.049],
- [16.424, 0.055, 0.055],
- [17.166, 0.038, 0.036],
- [41.655, 0.058, 0.055],
- [5.482, 0.008, 0.008],
- [2.146, 0.008, 0.008],
- [5.775, 0.01, 0.009],
- [15.499, 0.08, 0.077],
- [12.674, 0.379, 0.339],
- [0.195, 0.04, 0.036],
- [5.03, 0.051, 0.051],
- [8.391, 0.071, 0.076],
- [6.362, 0.659, 0.643],
- [14.969, 0.189, 0.18],
- [14.916, 0.212, 0.186],
- [0.713, 0.098, 0.098],
- [0.096, 0.007, 0.007],
- [0.088, 0.004, 0.004],
- [0.113, 0.004, 0.004],
- [0.132, 0.013, 0.013],
- [0.19, 0.006, 0.005],
- [0.151, 0.004, 0.004],
- [0.086, 0.004, 0.004]
+ [0.037, 0.005, 0.005],
+ [0.065, 0.006, 0.01],
+ [0.474, 0.006, 0.006],
+ [1.725, 0.006, 0.006],
+ [1.106, 0.081, 0.078],
+ [2.193, 0.037, 0.038],
+ [0.058, 0.002, 0.001],
+ [0.058, 0.007, 0.007],
+ [1.961, 0.138, 0.137],
+ [3.34, 0.142, 0.127],
+ [1.149, 0.015, 0.015],
+ [1.593, 0.018, 0.018],
+ [2.388, 0.054, 0.053],
+ [4.471, 0.156, 0.146],
+ [1.994, 0.055, 0.052],
+ [1.538, 0.108, 0.109],
+ [4.398, 0.154, 0.154],
+ [4.258, 0.123, 0.116],
+ [8.297, 0.557, 0.54],
+ [0.118, 0.001, 0.001],
+ [14.903, 0.061, 0.053],
+ [16.126, 0.053, 0.048],
+ [17.025, 0.045, 0.043],
+ [41.526, 0.066, 0.054],
+ [5.452, 0.01, 0.009],
+ [2.198, 0.009, 0.009],
+ [5.848, 0.01, 0.009],
+ [15.347, 0.084, 0.073],
+ [12.591, 0.376, 0.327],
+ [0.189, 0.048, 0.046],
+ [5.245, 0.051, 0.052],
+ [8.536, 0.08, 0.08],
+ [6.693, 0.727, 0.707],
+ [14.847, 0.238, 0.19],
+ [14.843, 0.201, 0.189],
+ [0.886, 0.101, 0.095],
+ [0.099, 0.008, 0.008],
+ [0.077, 0.004, 0.004],
+ [0.086, 0.004, 0.004],
+ [0.123, 0.016, 0.016],
+ [0.281, 0.006, 0.005],
+ [0.531, 0.004, 0.004],
+ [0.068, 0.006, 0.005]
]
}
+
diff --git a/run-benchmark.sh b/run-benchmark.sh
index c5816cebf..1a1b01272 100755
--- a/run-benchmark.sh
+++ b/run-benchmark.sh
@@ -2,11 +2,13 @@
machine=${machine:=c6a.4xlarge}
system=${system:=clickhouse}
+repo=${repo:=ClickHouse/ClickBench}
+branch=${branch:=main}
arch=$(aws ec2 describe-instance-types --instance-types $machine --query 'InstanceTypes[0].ProcessorInfo.SupportedArchitectures' --output text)
ami=$(aws ec2 describe-images --owners amazon --filters "Name=name,Values=ubuntu/images/hvm-ssd-gp3/ubuntu-noble-24.04*" "Name=architecture,Values=${arch}" "Name=state,Values=available" --query 'sort_by(Images, &CreationDate) | [-1].[ImageId]' --output text)
-sed "s/@system@/${system}/" < cloud-init.sh.in > cloud-init.sh
+sed "s^@system@^${system}^; s^@repo@^${repo}^; s^@branch@^${branch}^;" < cloud-init.sh.in > cloud-init.sh
AWS_PAGER='' aws ec2 run-instances --image-id $ami --instance-type $machine \
--block-device-mappings 'DeviceName=/dev/sda1,Ebs={DeleteOnTermination=true,VolumeSize=500,VolumeType=gp2}' \
diff --git a/sail-partitioned/c6a.4xlarge.json b/sail-partitioned/c6a.4xlarge.json
deleted file mode 100644
index dc5fe3a9f..000000000
--- a/sail-partitioned/c6a.4xlarge.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
- "system": "Sail (Parquet, partitioned)",
- "date": "2025-07-10",
- "machine": "c6a.4xlarge",
- "cluster_size": 1,
- "proprietary": "no",
- "tuned": "no",
- "tags": ["column-oriented"],
- "load_time": 0,
- "data_size": 14779976446,
- "result": [
- [0.153, 0.009, 0.009],
- [0.306, 0.119, 0.115],
- [0.342, 0.13, 0.125],
- [0.628, 0.12, 0.116],
- [1.099, 0.861, 0.873],
- [1.275, 0.848, 0.836],
- [2.607, 2.461, 2.395],
- [0.353, 0.129, 0.128],
- [1.32, 0.969, 0.971],
- [1.545, 1.066, 1.062],
- [0.664, 0.326, 0.332],
- [0.733, 0.361, 0.358],
- [1.395, 1.064, 1.062],
- [3.119, 1.797, 1.845],
- [1.499, 1.132, 1.13],
- [1.286, 1.01, 0.977],
- [2.971, 1.866, 1.896],
- [2.887, 1.894, 1.829],
- [5.563, 3.813, 3.866],
- [0.383, 0.147, 0.146],
- [9.698, 1.412, 1.417],
- [11.462, 1.267, 1.305],
- [20.132, 2.206, 2.216],
- [54.508, 4.366, 4.435],
- [2.836, 0.694, 0.694],
- [1.003, 0.585, 0.582],
- [2.864, 0.76, 0.755],
- [9.845, 2.775, 2.772],
- [11.387, 10.304, 10.372],
- [1.05, 0.821, 0.801],
- [2.533, 0.993, 0.984],
- [6.048, 1.07, 1.094],
- [4.937, 3.824, 4.078],
- [10.936, 5.151, 5.233],
- [10.894, 5.124, 5.18],
- [1.399, 1.081, 1.1],
- [0.851, 0.523, 0.519],
- [0.651, 0.425, 0.404],
- [0.757, 0.407, 0.383],
- [1.154, 0.698, 0.707],
- [0.67, 0.416, 0.399],
- [0.629, 0.35, 0.391],
- [0.671, 0.439, 0.452]
-]
-}
\ No newline at end of file
diff --git a/sail-partitioned/results/c6a.metal.json b/sail-partitioned/results/c6a.metal.json
new file mode 100644
index 000000000..a7bb686ca
--- /dev/null
+++ b/sail-partitioned/results/c6a.metal.json
@@ -0,0 +1,57 @@
+{
+ "system": "Sail (Parquet, partitioned)",
+ "date": "2025-10-09",
+ "machine": "c6a.metal",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["column-oriented"],
+ "load_time": 0,
+ "data_size": 14737666736,
+ "result": [
+ [0.195, 0.012, 0.013],
+ [0.299, 0.039, 0.045],
+ [0.339, 0.049, 0.053],
+ [0.51, 0.064, 0.062],
+ [0.64, 0.302, 0.262],
+ [0.962, 0.303, 0.274],
+ [0.19, 0.011, 0.012],
+ [0.29, 0.064, 0.079],
+ [0.908, 0.331, 0.307],
+ [1.381, 0.406, 0.36],
+ [0.634, 0.229, 0.193],
+ [0.755, 0.22, 0.199],
+ [0.996, 0.31, 0.293],
+ [2.446, 0.436, 0.458],
+ [1.085, 0.333, 0.3],
+ [0.717, 0.402, 0.37],
+ [2.356, 0.535, 0.468],
+ [2.272, 0.453, 0.399],
+ [4.351, 0.996, 1.045],
+ [0.485, 0.051, 0.064],
+ [9.585, 0.34, 0.292],
+ [11.221, 0.473, 0.378],
+ [21.756, 0.856, 0.835],
+ [55.811, 2.815, 2.608],
+ [2.697, 0.156, 0.121],
+ [0.881, 0.112, 0.102],
+ [2.7, 0.16, 0.12],
+ [9.626, 0.513, 0.549],
+ [8.772, 2.01, 1.994],
+ [0.43, 0.219, 0.203],
+ [2.455, 0.361, 0.304],
+ [5.94, 0.494, 0.4],
+ [4.852, 1.914, 1.844],
+ [10.144, 1.563, 1.649],
+ [10.202, 1.786, 1.737],
+ [0.805, 0.39, 0.334],
+ [9.72, 0.394, 0.324],
+ [8.751, 0.375, 0.294],
+ [9.68, 0.428, 0.337],
+ [18.566, 0.65, 0.545],
+ [2.728, 0.136, 0.126],
+ [1.92, 0.114, 0.109],
+ [1.203, 0.14, 0.095]
+]
+}
+
diff --git a/spark-auron/README.md b/spark-auron/README.md
new file mode 100644
index 000000000..d8adfabec
--- /dev/null
+++ b/spark-auron/README.md
@@ -0,0 +1,42 @@
+This README includes info on configuring Apache Auron (formerly Blaze) for ClickBench. For additional details, please refer to [Auron's docs](https://auron.apache.org/), [spark-accelerators README](../spark/README-accelerators.md) and [issue](https://github.com/apache/auron/issues/1287) discussing the results.
+
+### Run
+
+As usual, benchmark can be run via `./benchmark.sh`. Additionally, users can provide machine spec like `./benchmark.sh c6a.8xlarge` so script saves it in relevant file.
+
+## Notes
+
+### Debug
+
+- To find all unsupported queries from `log.txt`:
+```
+>>> grep -o 'expressions.*' log.txt | grep -v 'toprettystring' | grep -o ' .*' | sort | uniq -c
+
+ 45 cast(EventTime#4L as timestamp)
+ 12 cast(none#0L as timestamp)
+ 153 date_add(1970-01-01, EventDate#5)
+ 72 date_add(1970-01-01, none#0)
+ 24 date_add(1970-01-01, none#1)
+ 15 date_trunc(class org.apache.spark.sql.auron.NativeExprWrapper() dataType:StringType), ...)
+ 15 minute(class org.apache.spark.sql.auron.NativeExprWrapper() dataType:TimestampType), ...)
+ 9 regexp_replace(Referer#14, ^https?://(?:www.)?([^/]+)/.*$, $1, 1)
+ 6 regexp_replace(none#0, ^https?://(?:www.)?([^/]+)/.*$, $1, 1)
+```
+
+### Links
+
+- Refer to Auron's [`pom.xml`](https://github.com/apache/auron/blob/v5.0.0/pom.xml) for exact _version compatibility_ between Auron, Spark, Scala, and Java.
+- Download _pre-built JARs_ from the [Auron archives](https://auron.apache.org/archives).
+- View an example _Auron configuration_ in the [benchmarks documentation](https://auron.apache.org/documents/benchmarks.html#benchmark-configuration).
+
+### Configuration
+
+- As of version 5.0, Spark 3.5.5 is chosen since it's used for the `spark-3.5` shim (see `pom.xml`) and TPC-DS testing.
+- Apache Auron was previously named [Blaze](https://github.com/apache/auron/issues/1168). This change occurred after version 5.0, so previous naming references (links, settings) still remain. These will be updated in the next version.
+- In version 5.0, Auron generates extensive INFO logs (~55MB file after ~40 queries), which may impact system performance. This behavior will be manageable in next version and will require setting `spark.auron.native.log.level`.
+- Auron's memory configuration follows the example from the [benchmark page](https://auron.apache.org/documents/benchmarks.html#benchmark-configuration), specifically 1:2 split between memory and memoryOverhead.
+- For Auron modification of 29 query (containing `REGEXP_REPLACE`) is done similar to Apache Spark (see corresponding README.md) since Auron doesn't execute this function natively and falls back to Spark:
+```
+25/10/11 17:18:29 WARN NativeConverters: Falling back expression: scala.NotImplementedError: unsupported expression: (class org.apache.spark.sql.catalyst.expressions.RegExpReplace) regexp_replace(Referer#14, ^https?://(?:www.)?([^/]+)/.*$, $1, 1)
+```
+Moreover, running original query as-is leads to Rust's panic (see [comment](https://github.com/apache/auron/issues/1287#issuecomment-3387246375) for details).
diff --git a/spark-auron/benchmark.sh b/spark-auron/benchmark.sh
new file mode 100755
index 000000000..92af68dac
--- /dev/null
+++ b/spark-auron/benchmark.sh
@@ -0,0 +1,91 @@
+#!/bin/bash
+
+# Note: Keep in sync with spark-*/benchmark.sh (see README-accelerators.md for details)
+#
+# Highlights:
+# - pyspark==3.5.6 version is used (latest stable for Auron 5.0.0)
+# - Auron installation is added
+# - auto-save results
+
+# Install
+
+sudo apt-get update -y
+sudo apt-get install -y python3-pip python3-venv openjdk-17-jdk
+
+export JAVA_HOME="/usr/lib/jvm/java-17-openjdk-$(dpkg --print-architecture)/"
+export PATH=$JAVA_HOME/bin:$PATH
+
+python3 -m venv myenv
+source myenv/bin/activate
+pip install pyspark==3.5.5 psutil
+
+# Load the data
+
+wget --continue --progress=dot:giga 'https://datasets.clickhouse.com/hits_compatible/hits.parquet'
+
+# Install Auron
+
+AURON_JAR_URL='https://github.com/apache/auron/releases/download/v5.0.0/blaze-engine-spark-3.5-release-5.0.0-SNAPSHOT.jar'
+
+wget --continue --progress=dot:giga $AURON_JAR_URL -O auron.jar
+
+# Run the queries
+
+./run.sh >log.txt 2>&1
+
+# Print results to stdout as required
+cat log.txt | grep -P '^Time:\s+([\d\.]+)|Failure!' | sed -r -e 's/Time: //; s/^Failure!$/null/' |
+ awk '{ if (i % 3 == 0) { printf "[" }; printf $1; if (i % 3 != 2) { printf "," } else { print "]," }; ++i; }'
+
+DATA_SIZE=$(du -b hits.parquet | cut -f1)
+
+echo "Data size: $DATA_SIZE"
+echo "Load time: 0"
+
+# Save results as JSON
+
+MACHINE="${1:-c6a.4xlarge}" # Use first argument as machine name, default to c6a.4xlarge
+AURON_VERSION=$(echo $AURON_JAR_URL | grep -Po "\d.\d.\d" | head -n 1)
+SPARK_VERSION=$(pip freeze | grep '^pyspark==' | cut -d '=' -f3)
+
+mkdir -p results
+
+(
+cat << EOF
+{
+ "system": "Spark (Auron)",
+ "date": "$(date +%Y-%m-%d)",
+ "machine": "${MACHINE}",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "comment": "Using Auron ${AURON_VERSION} with Spark ${SPARK_VERSION}",
+ "tags": ["Java", "Rust", "column-oriented", "Spark derivative", "DataFusion", "Parquet"],
+ "load_time": 0,
+ "data_size": ${DATA_SIZE},
+ "result": [
+EOF
+
+cat log.txt | grep -P '^Time:\s+([\d\.]+)|Failure!' | sed -r -e 's/Time: //; s/^Failure!$/null/' |
+ awk -v total=$(grep -cP '^Time:\s+[\d\.]+|Failure!' log.txt) '
+ {
+ if (i % 3 == 0) printf "\t\t[";
+ if ($1 == "null") printf "null";
+ else printf "%.3f", $1;
+ if (i % 3 != 2) printf ", ";
+ else {
+ if (i < total - 1) printf "],\n";
+ else printf "]";
+ }
+ i++;
+ }'
+
+cat << EOF
+
+ ]
+}
+EOF
+) > "results/${MACHINE}.json"
+
+echo "Results have been saved to results/${MACHINE}.json"
+
diff --git a/spark-auron/queries.sql b/spark-auron/queries.sql
new file mode 100644
index 000000000..8fafcbcf9
--- /dev/null
+++ b/spark-auron/queries.sql
@@ -0,0 +1,43 @@
+SELECT COUNT(*) FROM hits;
+SELECT COUNT(*) FROM hits WHERE AdvEngineID <> 0;
+SELECT SUM(AdvEngineID), COUNT(*), AVG(ResolutionWidth) FROM hits;
+SELECT AVG(UserID) FROM hits;
+SELECT COUNT(DISTINCT UserID) FROM hits;
+SELECT COUNT(DISTINCT SearchPhrase) FROM hits;
+SELECT MIN(EventDate), MAX(EventDate) FROM hits;
+SELECT AdvEngineID, COUNT(*) FROM hits WHERE AdvEngineID <> 0 GROUP BY AdvEngineID ORDER BY COUNT(*) DESC;
+SELECT RegionID, COUNT(DISTINCT UserID) AS u FROM hits GROUP BY RegionID ORDER BY u DESC LIMIT 10;
+SELECT RegionID, SUM(AdvEngineID), COUNT(*) AS c, AVG(ResolutionWidth), COUNT(DISTINCT UserID) FROM hits GROUP BY RegionID ORDER BY c DESC LIMIT 10;
+SELECT MobilePhoneModel, COUNT(DISTINCT UserID) AS u FROM hits WHERE MobilePhoneModel <> '' GROUP BY MobilePhoneModel ORDER BY u DESC LIMIT 10;
+SELECT MobilePhone, MobilePhoneModel, COUNT(DISTINCT UserID) AS u FROM hits WHERE MobilePhoneModel <> '' GROUP BY MobilePhone, MobilePhoneModel ORDER BY u DESC LIMIT 10;
+SELECT SearchPhrase, COUNT(*) AS c FROM hits WHERE SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT SearchPhrase, COUNT(DISTINCT UserID) AS u FROM hits WHERE SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY u DESC LIMIT 10;
+SELECT SearchEngineID, SearchPhrase, COUNT(*) AS c FROM hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT UserID, COUNT(*) FROM hits GROUP BY UserID ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID, SearchPhrase, COUNT(*) FROM hits GROUP BY UserID, SearchPhrase ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID, SearchPhrase, COUNT(*) FROM hits GROUP BY UserID, SearchPhrase LIMIT 10;
+SELECT UserID, extract(minute FROM EventTime) AS m, SearchPhrase, COUNT(*) FROM hits GROUP BY UserID, m, SearchPhrase ORDER BY COUNT(*) DESC LIMIT 10;
+SELECT UserID FROM hits WHERE UserID = 435090932899640449;
+SELECT COUNT(*) FROM hits WHERE URL LIKE '%google%';
+SELECT SearchPhrase, MIN(URL), COUNT(*) AS c FROM hits WHERE URL LIKE '%google%' AND SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT SearchPhrase, MIN(URL), MIN(Title), COUNT(*) AS c, COUNT(DISTINCT UserID) FROM hits WHERE Title LIKE '%Google%' AND URL NOT LIKE '%.google.%' AND SearchPhrase <> '' GROUP BY SearchPhrase ORDER BY c DESC LIMIT 10;
+SELECT * FROM hits WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10;
+SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime LIMIT 10;
+SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY SearchPhrase LIMIT 10;
+SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime, SearchPhrase LIMIT 10;
+SELECT CounterID, AVG(length(URL)) AS l, COUNT(*) AS c FROM hits WHERE URL <> '' GROUP BY CounterID HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '$1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT SUM(ResolutionWidth), SUM(ResolutionWidth + 1), SUM(ResolutionWidth + 2), SUM(ResolutionWidth + 3), SUM(ResolutionWidth + 4), SUM(ResolutionWidth + 5), SUM(ResolutionWidth + 6), SUM(ResolutionWidth + 7), SUM(ResolutionWidth + 8), SUM(ResolutionWidth + 9), SUM(ResolutionWidth + 10), SUM(ResolutionWidth + 11), SUM(ResolutionWidth + 12), SUM(ResolutionWidth + 13), SUM(ResolutionWidth + 14), SUM(ResolutionWidth + 15), SUM(ResolutionWidth + 16), SUM(ResolutionWidth + 17), SUM(ResolutionWidth + 18), SUM(ResolutionWidth + 19), SUM(ResolutionWidth + 20), SUM(ResolutionWidth + 21), SUM(ResolutionWidth + 22), SUM(ResolutionWidth + 23), SUM(ResolutionWidth + 24), SUM(ResolutionWidth + 25), SUM(ResolutionWidth + 26), SUM(ResolutionWidth + 27), SUM(ResolutionWidth + 28), SUM(ResolutionWidth + 29), SUM(ResolutionWidth + 30), SUM(ResolutionWidth + 31), SUM(ResolutionWidth + 32), SUM(ResolutionWidth + 33), SUM(ResolutionWidth + 34), SUM(ResolutionWidth + 35), SUM(ResolutionWidth + 36), SUM(ResolutionWidth + 37), SUM(ResolutionWidth + 38), SUM(ResolutionWidth + 39), SUM(ResolutionWidth + 40), SUM(ResolutionWidth + 41), SUM(ResolutionWidth + 42), SUM(ResolutionWidth + 43), SUM(ResolutionWidth + 44), SUM(ResolutionWidth + 45), SUM(ResolutionWidth + 46), SUM(ResolutionWidth + 47), SUM(ResolutionWidth + 48), SUM(ResolutionWidth + 49), SUM(ResolutionWidth + 50), SUM(ResolutionWidth + 51), SUM(ResolutionWidth + 52), SUM(ResolutionWidth + 53), SUM(ResolutionWidth + 54), SUM(ResolutionWidth + 55), SUM(ResolutionWidth + 56), SUM(ResolutionWidth + 57), SUM(ResolutionWidth + 58), SUM(ResolutionWidth + 59), SUM(ResolutionWidth + 60), SUM(ResolutionWidth + 61), SUM(ResolutionWidth + 62), SUM(ResolutionWidth + 63), SUM(ResolutionWidth + 64), SUM(ResolutionWidth + 65), SUM(ResolutionWidth + 66), SUM(ResolutionWidth + 67), SUM(ResolutionWidth + 68), SUM(ResolutionWidth + 69), SUM(ResolutionWidth + 70), SUM(ResolutionWidth + 71), SUM(ResolutionWidth + 72), SUM(ResolutionWidth + 73), SUM(ResolutionWidth + 74), SUM(ResolutionWidth + 75), SUM(ResolutionWidth + 76), SUM(ResolutionWidth + 77), SUM(ResolutionWidth + 78), SUM(ResolutionWidth + 79), SUM(ResolutionWidth + 80), SUM(ResolutionWidth + 81), SUM(ResolutionWidth + 82), SUM(ResolutionWidth + 83), SUM(ResolutionWidth + 84), SUM(ResolutionWidth + 85), SUM(ResolutionWidth + 86), SUM(ResolutionWidth + 87), SUM(ResolutionWidth + 88), SUM(ResolutionWidth + 89) FROM hits;
+SELECT SearchEngineID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
+SELECT URL, COUNT(*) AS c FROM hits GROUP BY URL ORDER BY c DESC LIMIT 10;
+SELECT 1, URL, COUNT(*) AS c FROM hits GROUP BY 1, URL ORDER BY c DESC LIMIT 10;
+SELECT ClientIP, ClientIP - 1, ClientIP - 2, ClientIP - 3, COUNT(*) AS c FROM hits GROUP BY ClientIP, ClientIP - 1, ClientIP - 2, ClientIP - 3 ORDER BY c DESC LIMIT 10;
+SELECT URL, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND DontCountHits = 0 AND IsRefresh = 0 AND URL <> '' GROUP BY URL ORDER BY PageViews DESC LIMIT 10;
+SELECT Title, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND DontCountHits = 0 AND IsRefresh = 0 AND Title <> '' GROUP BY Title ORDER BY PageViews DESC LIMIT 10;
+SELECT URL, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND IsRefresh = 0 AND IsLink <> 0 AND IsDownload = 0 GROUP BY URL ORDER BY PageViews DESC LIMIT 10 OFFSET 1000;
+SELECT TraficSourceID, SearchEngineID, AdvEngineID, CASE WHEN (SearchEngineID = 0 AND AdvEngineID = 0) THEN Referer ELSE '' END AS Src, URL AS Dst, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND IsRefresh = 0 GROUP BY TraficSourceID, SearchEngineID, AdvEngineID, Src, Dst ORDER BY PageViews DESC LIMIT 10 OFFSET 1000;
+SELECT URLHash, EventDate, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND IsRefresh = 0 AND TraficSourceID IN (-1, 6) AND RefererHash = 3594120000172545465 GROUP BY URLHash, EventDate ORDER BY PageViews DESC LIMIT 10 OFFSET 100;
+SELECT WindowClientWidth, WindowClientHeight, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-01' AND EventDate <= '2013-07-31' AND IsRefresh = 0 AND DontCountHits = 0 AND URLHash = 2868770270353813622 GROUP BY WindowClientWidth, WindowClientHeight ORDER BY PageViews DESC LIMIT 10 OFFSET 10000;
+SELECT DATE_TRUNC('minute', EventTime) AS M, COUNT(*) AS PageViews FROM hits WHERE CounterID = 62 AND EventDate >= '2013-07-14' AND EventDate <= '2013-07-15' AND IsRefresh = 0 AND DontCountHits = 0 GROUP BY DATE_TRUNC('minute', EventTime) ORDER BY DATE_TRUNC('minute', EventTime) LIMIT 10 OFFSET 1000;
diff --git a/spark-auron/query.py b/spark-auron/query.py
new file mode 100755
index 000000000..b07b29e6b
--- /dev/null
+++ b/spark-auron/query.py
@@ -0,0 +1,63 @@
+#!/usr/bin/env python3
+
+"""
+Note: Keep in sync with spark-*/query.py (see README-accelerators.md for details)
+
+Highlights:
+- memory is split between heap (for Spark) and memoryOverhead (for Auron)
+- Auron configuration is added to `SparkSession`
+"""
+
+from pyspark.sql import SparkSession
+import pyspark.sql.functions as F
+
+import psutil
+import sys
+import timeit
+
+
+query = sys.stdin.read()
+print(query)
+
+# Calculate available memory to configurate SparkSession (in MB)
+ram = int(round(psutil.virtual_memory().available / (1024 ** 2) * 0.7))
+exec_memory = ram // 3
+exec_overhead = ram - exec_memory
+print(f"SparkSession will be set with {exec_memory} MB of memory and {exec_overhead} MB of memoryOverhead (total {ram} MB)")
+
+builder = (
+ SparkSession
+ .builder
+ .appName("ClickBench")
+ .config("spark.driver", "local[*]") # To ensure using all cores
+ .config("spark.driver.memory", f"{exec_memory}m")
+ .config("spark.sql.parquet.binaryAsString", True) # Treat binary as string to get correct length calculations and text results
+
+ # Additional Auron configuration
+ .config("spark.jars", "auron.jar")
+ .config("spark.driver.extraClassPath", "auron.jar")
+ .config("spark.auron.enable", True)
+ .config("spark.sql.extensions", "org.apache.spark.sql.blaze.BlazeSparkSessionExtension")
+ .config("spark.shuffle.manager", "org.apache.spark.sql.execution.blaze.shuffle.BlazeShuffleManager")
+ .config("spark.memory.offHeap.enabled", "false")
+ .config("spark.driver.memoryOverhead", exec_overhead)
+)
+
+spark = builder.getOrCreate()
+
+df = spark.read.parquet("hits.parquet")
+# Do casting before creating the view so no need to change to unreadable integer dates in SQL
+df = df.withColumn("EventTime", F.col("EventTime").cast("timestamp"))
+df = df.withColumn("EventDate", F.date_add(F.lit("1970-01-01"), F.col("EventDate")))
+df.createOrReplaceTempView("hits")
+
+for try_num in range(3):
+ try:
+ start = timeit.default_timer()
+ result = spark.sql(query)
+ result.show(100) # some queries should return more than 20 rows which is the default show limit
+ end = timeit.default_timer()
+ print("Time: ", end - start)
+ except Exception as e:
+ print(e)
+ print("Failure!")
diff --git a/spark-auron/results/c6a.2xlarge.json b/spark-auron/results/c6a.2xlarge.json
new file mode 100644
index 000000000..8e341be78
--- /dev/null
+++ b/spark-auron/results/c6a.2xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-15",
+ "machine": "c6a.2xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [58.147, 45.917, 44.68],
+ [3.78, 1.588, 1.364],
+ [4.284, 1.818, 1.583],
+ [4.214, 1.716, 1.468],
+ [7.226, 4.955, 4.095],
+ [6.292, 3.798, 3.535],
+ [5.681, 3.129, 2.906],
+ [3.862, 1.583, 1.388],
+ [8.208, 5.713, 5.266],
+ [11.706, 8.854, 8.489],
+ [4.775, 2.156, 1.855],
+ [4.942, 2.29, 2.017],
+ [6.35, 3.741, 3.514],
+ [9.479, 7.06, 7.575],
+ [6.727, 4.109, 3.773],
+ [8.197, 5.7, 5.321],
+ [11.766, 9.126, 9.003],
+ [8.34, 5.973, 5.718],
+ [20.273, 17.703, 16.344],
+ [3.662, 1.476, 1.365],
+ [11.386, 3.552, 3.304],
+ [13.341, 4.136, 3.877],
+ [23.938, 5.844, 5.524],
+ [58.805, 46.323, 44.78],
+ [5.744, 2.92, 2.58],
+ [4.617, 2.276, 2.007],
+ [5.682, 2.862, 2.738],
+ [11.632, 5.297, 4.882],
+ [24.069, 20.545, 20.259],
+ [11.786, 8.8, 8.561],
+ [6.585, 3.875, 3.582],
+ [9.556, 5.403, 5.068],
+ [24.313, 21.462, 21.299],
+ [16.352, 12.018, 11.683],
+ [16.851, 11.87, 11.516],
+ [8.102, 5.429, 5.111],
+ [4.132, 1.765, 1.553],
+ [3.973, 1.594, 1.486],
+ [4.281, 1.788, 1.476],
+ [5.941, 2.869, 2.463],
+ [4.419, 1.743, 1.506],
+ [4.238, 1.667, 1.376],
+ [4.319, 1.698, 1.43]
+]
+}
+
diff --git a/spark-auron/results/c6a.4xlarge.json b/spark-auron/results/c6a.4xlarge.json
new file mode 100644
index 000000000..1f4854b33
--- /dev/null
+++ b/spark-auron/results/c6a.4xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-15",
+ "machine": "c6a.4xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [57.95, 11.492, 11.457],
+ [3.21, 1.092, 0.92],
+ [3.348, 1.173, 1.005],
+ [3.288, 1.112, 1.022],
+ [5.213, 2.968, 2.781],
+ [4.752, 2.557, 2.327],
+ [4.155, 1.767, 1.653],
+ [3.378, 1.108, 0.927],
+ [6.092, 3.817, 3.519],
+ [7.945, 5.662, 5.39],
+ [3.942, 1.546, 1.294],
+ [4.011, 1.649, 1.369],
+ [4.834, 2.557, 2.302],
+ [6.588, 4.176, 3.878],
+ [5.164, 2.824, 2.572],
+ [5.615, 3.412, 3.134],
+ [8.193, 5.884, 5.59],
+ [5.895, 3.731, 3.478],
+ [13.321, 10.407, 10.284],
+ [3.13, 1.059, 1.03],
+ [11.402, 2.634, 2.465],
+ [13.181, 2.977, 2.783],
+ [24.005, 4.626, 4.435],
+ [58.625, 17.595, 17.347],
+ [4.405, 1.754, 1.684],
+ [3.605, 1.535, 1.351],
+ [4.352, 1.854, 1.771],
+ [11.816, 3.78, 3.534],
+ [14.537, 11.357, 11.106],
+ [11.147, 8.578, 8.39],
+ [5.114, 2.673, 2.471],
+ [8.483, 3.056, 2.797],
+ [16.698, 14.124, 14.025],
+ [14.732, 9.005, 8.593],
+ [14.801, 8.886, 8.714],
+ [5.66, 3.353, 3.103],
+ [3.589, 1.232, 1.078],
+ [3.42, 1.102, 0.963],
+ [3.745, 1.235, 1.045],
+ [5.222, 2.353, 2.083],
+ [3.91, 1.276, 1.088],
+ [3.727, 1.126, 1.038],
+ [3.756, 1.22, 1.031]
+]
+}
+
diff --git a/spark-auron/results/c6a.large.json b/spark-auron/results/c6a.large.json
new file mode 100644
index 000000000..192f9a936
--- /dev/null
+++ b/spark-auron/results/c6a.large.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-16",
+ "machine": "c6a.large",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [82.112, 78.673, 78.263],
+ [9.207, 5.154, 4.582],
+ [10.254, 6.34, 5.5],
+ [10.524, 5.919, 5.262],
+ [20.023, 15.39, 14.152],
+ [21.696, 14.237, 13.105],
+ [16.612, 11.33, 10.756],
+ [10.041, 5.681, 4.763],
+ [22.896, 17.96, 16.811],
+ [34.947, 29.701, 28.602],
+ [12.31, 7.5, 6.51],
+ [12.952, 8.028, 6.892],
+ [21.513, 16.942, 14.904],
+ [36.368, 29.819, 29.818],
+ [21.777, 17.725, 15.727],
+ [23.702, 18.537, 18.009],
+ [37.063, 31.309, 29.986],
+ [24.134, 18.42, 17.547],
+ [68.087, 60.277, 61.653],
+ [9.385, 4.706, 4.724],
+ [19.917, 12.583, 11.728],
+ [22.729, 15.157, 13.966],
+ [34.339, 26.264, 27.813],
+ [102.081, 95.868, 94.019],
+ [17.413, 10.05, 9.253],
+ [13.75, 8.45, 7.468],
+ [16.052, 10.758, 9.682],
+ [24.85, 17.201, 16.297],
+ [84.127, 76.615, 77.281],
+ [36.997, 31.816, 30.645],
+ [22.694, 15.746, 14.702],
+ [25.961, 19.053, 17.989],
+ [84.071, 77.628, 76.567],
+ [69.31, 61.847, 60.98],
+ [65.929, 60.132, 60.4],
+ [22.115, 17.563, 16.639],
+ [11.013, 5.887, 4.945],
+ [10.154, 5.675, 4.668],
+ [10.201, 5.709, 4.94],
+ [13.111, 8.155, 7.026],
+ [10.34, 6.111, 4.992],
+ [10.234, 5.753, 4.651],
+ [10.169, 6.084, 4.994]
+]
+}
+
diff --git a/spark-auron/results/c6a.metal.json b/spark-auron/results/c6a.metal.json
new file mode 100644
index 000000000..58e4d3012
--- /dev/null
+++ b/spark-auron/results/c6a.metal.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-16",
+ "machine": "c6a.metal",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [75.585, 38.301, 38.048],
+ [39.201, 37.094, 37.646],
+ [39.502, 37.295, 35.012],
+ [39.454, 36.901, 35.406],
+ [50.535, 47.766, 46.557],
+ [77.835, 75.399, 73.981],
+ [44.448, 39.91, 36.836],
+ [38.729, 37.46, 35.939],
+ [81.341, 75.246, 74.077],
+ [82.033, 73.671, 74.671],
+ [39.896, 35.735, 36.352],
+ [40.217, 38.078, 36.499],
+ [81.086, 73.669, 72.985],
+ [113.514, 111.96, 112.165],
+ [74.705, 73.781, 74.067],
+ [50.934, 46.38, 47],
+ [82.543, 76.633, 76.459],
+ [41.262, 40.882, 36.326],
+ [81.797, 76.921, 77.889],
+ [13.317, 14.833, 10.793],
+ [39.798, 35.889, 35.928],
+ [39.659, 36.078, 37.112],
+ [43.649, 37.584, 37.285],
+ [77.906, 40.807, 40.539],
+ [40.531, 35.889, 37.18],
+ [39.227, 35.294, 35.756],
+ [40.339, 36.783, 35.342],
+ [39.546, 37.271, 35.839],
+ [83.408, 79.416, 77.833],
+ [41.528, 36.724, 36.976],
+ [44.324, 41.545, 40.953],
+ [79.989, 74.188, 73.242],
+ [81.781, 75.443, 74.846],
+ [82.856, 77.742, 76.08],
+ [83.197, 78.911, 76.303],
+ [51.941, 48.019, 46.468],
+ [40.635, 36.332, 38.299],
+ [39.538, 36.796, 35.579],
+ [39.968, 36.98, 36.524],
+ [44.931, 40.136, 41.553],
+ [40.499, 37.395, 37.654],
+ [39.291, 37.156, 35.503],
+ [41.102, 36.042, 36.827]
+]
+}
+
diff --git a/spark-auron/results/c6a.xlarge.json b/spark-auron/results/c6a.xlarge.json
new file mode 100644
index 000000000..f6d43f7ce
--- /dev/null
+++ b/spark-auron/results/c6a.xlarge.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-16",
+ "machine": "c6a.xlarge",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [65.457, 52.707, 53.013],
+ [5.478, 2.799, 2.254],
+ [6.286, 3.144, 2.751],
+ [5.824, 3.076, 2.686],
+ [11.989, 8.605, 7.837],
+ [10.663, 7.857, 6.626],
+ [9.222, 5.6, 5.372],
+ [5.814, 2.851, 2.356],
+ [12.8, 9.755, 9.08],
+ [19.137, 15.381, 14.621],
+ [7.244, 3.99, 3.315],
+ [7.618, 4.241, 3.556],
+ [11.329, 8.127, 7.649],
+ [18.21, 14.183, 13.46],
+ [12.17, 8.654, 8.234],
+ [12.906, 9.63, 9.129],
+ [20.398, 15.945, 15.457],
+ [13.077, 9.932, 9.443],
+ [35.112, 30.755, 30.445],
+ [5.747, 2.588, 2.443],
+ [11.952, 6.57, 5.919],
+ [13.463, 7.158, 6.78],
+ [24.258, 10.725, 10.215],
+ [59.173, 50.414, 50.095],
+ [8.854, 4.925, 4.755],
+ [6.901, 4.183, 3.787],
+ [9.07, 5.237, 4.961],
+ [13.334, 9.261, 8.735],
+ [43.633, 38.08, 37.865],
+ [19.686, 15.689, 15.172],
+ [11.797, 7.945, 7.404],
+ [13.691, 9.653, 9.24],
+ [42.979, 40.129, 38.605],
+ [27.019, 21.829, 22.606],
+ [26.506, 22.02, 22.18],
+ [13.186, 9.78, 9.511],
+ [6.134, 3.103, 2.421],
+ [5.873, 2.903, 2.346],
+ [6.399, 3.055, 2.395],
+ [8.188, 4.49, 3.745],
+ [6.573, 3.124, 2.55],
+ [6.299, 2.948, 2.396],
+ [6.3, 3.07, 2.399]
+]
+}
+
diff --git a/spark-auron/results/c7a.metal-48xl.json b/spark-auron/results/c7a.metal-48xl.json
new file mode 100644
index 000000000..084c6301e
--- /dev/null
+++ b/spark-auron/results/c7a.metal-48xl.json
@@ -0,0 +1,57 @@
+{
+ "system": "Spark (Auron)",
+ "date": "2025-10-16",
+ "machine": "c7a.metal-48xl",
+ "cluster_size": 1,
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": ["Java","Rust","column-oriented","Spark derivative"],
+ "load_time": 0,
+ "data_size": 14779976446,
+ "result": [
+ [72.917, 37.208, 36.073],
+ [42.566, 37.155, 36.966],
+ [40.477, 37.208, 35.972],
+ [40.879, 37.252, 36.44],
+ [51.133, 46.912, 46.947],
+ [84.434, 77.317, 79.121],
+ [41.287, 38.446, 37.57],
+ [39.734, 36.946, 36.284],
+ [83.13, 75.294, 76.694],
+ [81.958, 77.498, 80.801],
+ [43.502, 38.235, 36.93],
+ [42.951, 37.495, 38.884],
+ [87.197, 76.613, 76.353],
+ [127.117, 119.968, 117.481],
+ [81.298, 83.37, 83.211],
+ [50.191, 48.348, 46.665],
+ [82.702, 78.844, 77.609],
+ [42.218, 38.067, 37.652],
+ [87.706, 82.183, 79.463],
+ [10.136, 13.682, 15.128],
+ [40.315, 37.343, 37.033],
+ [42.428, 37.615, 36.085],
+ [45.01, 37.916, 38.022],
+ [74.679, 39.401, 37.675],
+ [41.267, 38.353, 38.075],
+ [41.171, 36.616, 36.421],
+ [40.445, 37.23, 36.348],
+ [40.519, 39.133, 36.81],
+ [88.596, 78.613, 78.634],
+ [42.973, 38.295, 37.636],
+ [46.782, 42.805, 41.347],
+ [78.699, 77.344, 76.179],
+ [84.487, 80.711, 82.391],
+ [87.69, 80.691, 80.081],
+ [82.491, 81.05, 79.722],
+ [50.891, 56.102, 47.895],
+ [43.132, 38.194, 38.858],
+ [40.887, 36.817, 37.732],
+ [40.749, 36.925, 37.365],
+ [45.396, 40.952, 40.577],
+ [41.626, 37.999, 37.025],
+ [40.868, 38.019, 36.439],
+ [43.151, 37.532, 36.32]
+]
+}
+
diff --git a/spark-auron/run.sh b/spark-auron/run.sh
new file mode 100755
index 000000000..8c9ca1289
--- /dev/null
+++ b/spark-auron/run.sh
@@ -0,0 +1,10 @@
+#!/bin/bash
+
+# Note: Keep in sync with spark-*/run.sh (see README-accelerators.md for details)
+
+cat queries.sql | while read query; do
+ sync
+ echo 3 | sudo tee /proc/sys/vm/drop_caches >/dev/null
+
+ ./query.py <<< "${query}"
+done
diff --git a/spark-auron/template.json b/spark-auron/template.json
new file mode 100644
index 000000000..9b1bc1d2f
--- /dev/null
+++ b/spark-auron/template.json
@@ -0,0 +1,11 @@
+{
+ "system": "Spark (Auron)",
+ "proprietary": "no",
+ "tuned": "no",
+ "tags": [
+ "Java",
+ "Rust",
+ "column-oriented",
+ "Spark derivative"
+ ]
+}
diff --git a/spark-comet/README.md b/spark-comet/README.md
index 17c08371c..9e731f6ea 100644
--- a/spark-comet/README.md
+++ b/spark-comet/README.md
@@ -4,7 +4,9 @@ This README includes info on configuring Apache Comet for ClickBench. For additi
As usual, benchmark can be run via `./benchmark.sh`. Additionally, users can provide machine spec like `./benchmark.sh c6a.8xlarge` so script saves it in relevant file.
-### Notes
+## Notes
+
+### Debug
- To find all unsupported queries from `log.txt` (requires running bench in debug mode):
```bash
@@ -15,9 +17,13 @@ As usual, benchmark can be run via `./benchmark.sh`. Additionally, users can pro
123 +- HashAggregate [COMET: distinct aggregates are not supported]
...
```
+
+### Links
+
- Check [here](https://datafusion.apache.org/comet/user-guide/installation.html#supported-spark-versions) for _version compatibility_ between Spark and Comet.
- Check [here](https://datafusion.apache.org/comet/user-guide/installation.html#using-a-published-jar-file) for _links to Comet jar_.
- Check [here](https://datafusion.apache.org/comet/user-guide/installation.html#run-spark-shell-with-comet-enabled) for _basic Comet configuration_.
+- Check [here](https://github.com/apache/datafusion-comet/blob/main/docs/spark_expressions_support.md?plain=1) for _a list of (un-)supported expressions_.
### Configuration
@@ -27,3 +33,4 @@ Therefore, we need to split available memory between heap (for Spark) and off-he
- `spark.comet.regexp.allowIncompatible=True` allows Comet to use incompatible regular expressions instead of falling back to Spark (check [docs](https://datafusion.apache.org/comet/user-guide/compatibility.html#regular-expressions) for details).
- `spark.comet.scan.allowIncompatible=True` allows Comet to use different parquet readers to prevent query failures (check [issue](https://github.com/apache/datafusion-comet/issues/2035#issuecomment-3090666597) for details).
What happens here: `hits.parquet` contains `short` type columns, so Comet uses the `native_comet` reader for compatibility. However, this reader [doesn't work](https://github.com/apache/datafusion-comet/issues/2038) for some queries (e.g., query 40), causing Comet to fail. As a workaround, we can allow Comet to produce results incompatible with Spark, enabling it to use [other readers](https://datafusion.apache.org/comet/user-guide/compatibility.html#parquet-scans) and successfully execute these queries.
+- For Comet modification of 29 query (containing `REGEXP_REPLACE`) is done similar to Apache Spark (see corresponding README.md) since Comet [doesn't execute this function natively](https://github.com/apache/datafusion-comet/blob/1c462bc6c41b05e69b0ea7dd658e135648deff6c/docs/spark_expressions_support.md?plain=1#L420) and falls back to Spark.
diff --git a/spark-comet/queries.sql b/spark-comet/queries.sql
index 31f65fc89..8fafcbcf9 100644
--- a/spark-comet/queries.sql
+++ b/spark-comet/queries.sql
@@ -26,7 +26,7 @@ SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime LIMIT
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY SearchPhrase LIMIT 10;
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime, SearchPhrase LIMIT 10;
SELECT CounterID, AVG(length(URL)) AS l, COUNT(*) AS c FROM hits WHERE URL <> '' GROUP BY CounterID HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
-SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '\1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '$1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
SELECT SUM(ResolutionWidth), SUM(ResolutionWidth + 1), SUM(ResolutionWidth + 2), SUM(ResolutionWidth + 3), SUM(ResolutionWidth + 4), SUM(ResolutionWidth + 5), SUM(ResolutionWidth + 6), SUM(ResolutionWidth + 7), SUM(ResolutionWidth + 8), SUM(ResolutionWidth + 9), SUM(ResolutionWidth + 10), SUM(ResolutionWidth + 11), SUM(ResolutionWidth + 12), SUM(ResolutionWidth + 13), SUM(ResolutionWidth + 14), SUM(ResolutionWidth + 15), SUM(ResolutionWidth + 16), SUM(ResolutionWidth + 17), SUM(ResolutionWidth + 18), SUM(ResolutionWidth + 19), SUM(ResolutionWidth + 20), SUM(ResolutionWidth + 21), SUM(ResolutionWidth + 22), SUM(ResolutionWidth + 23), SUM(ResolutionWidth + 24), SUM(ResolutionWidth + 25), SUM(ResolutionWidth + 26), SUM(ResolutionWidth + 27), SUM(ResolutionWidth + 28), SUM(ResolutionWidth + 29), SUM(ResolutionWidth + 30), SUM(ResolutionWidth + 31), SUM(ResolutionWidth + 32), SUM(ResolutionWidth + 33), SUM(ResolutionWidth + 34), SUM(ResolutionWidth + 35), SUM(ResolutionWidth + 36), SUM(ResolutionWidth + 37), SUM(ResolutionWidth + 38), SUM(ResolutionWidth + 39), SUM(ResolutionWidth + 40), SUM(ResolutionWidth + 41), SUM(ResolutionWidth + 42), SUM(ResolutionWidth + 43), SUM(ResolutionWidth + 44), SUM(ResolutionWidth + 45), SUM(ResolutionWidth + 46), SUM(ResolutionWidth + 47), SUM(ResolutionWidth + 48), SUM(ResolutionWidth + 49), SUM(ResolutionWidth + 50), SUM(ResolutionWidth + 51), SUM(ResolutionWidth + 52), SUM(ResolutionWidth + 53), SUM(ResolutionWidth + 54), SUM(ResolutionWidth + 55), SUM(ResolutionWidth + 56), SUM(ResolutionWidth + 57), SUM(ResolutionWidth + 58), SUM(ResolutionWidth + 59), SUM(ResolutionWidth + 60), SUM(ResolutionWidth + 61), SUM(ResolutionWidth + 62), SUM(ResolutionWidth + 63), SUM(ResolutionWidth + 64), SUM(ResolutionWidth + 65), SUM(ResolutionWidth + 66), SUM(ResolutionWidth + 67), SUM(ResolutionWidth + 68), SUM(ResolutionWidth + 69), SUM(ResolutionWidth + 70), SUM(ResolutionWidth + 71), SUM(ResolutionWidth + 72), SUM(ResolutionWidth + 73), SUM(ResolutionWidth + 74), SUM(ResolutionWidth + 75), SUM(ResolutionWidth + 76), SUM(ResolutionWidth + 77), SUM(ResolutionWidth + 78), SUM(ResolutionWidth + 79), SUM(ResolutionWidth + 80), SUM(ResolutionWidth + 81), SUM(ResolutionWidth + 82), SUM(ResolutionWidth + 83), SUM(ResolutionWidth + 84), SUM(ResolutionWidth + 85), SUM(ResolutionWidth + 86), SUM(ResolutionWidth + 87), SUM(ResolutionWidth + 88), SUM(ResolutionWidth + 89) FROM hits;
SELECT SearchEngineID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, ClientIP ORDER BY c DESC LIMIT 10;
SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
diff --git a/spark-comet/query.py b/spark-comet/query.py
index 29c84981e..50358069a 100755
--- a/spark-comet/query.py
+++ b/spark-comet/query.py
@@ -14,28 +14,25 @@
import os
import psutil
-import re
import sys
import timeit
query = sys.stdin.read()
-# Replace \1 to $1 because spark recognizes only this pattern style (in query 28)
-query = re.sub(r"""(REGEXP_REPLACE\(.*?,\s*('[^']*')\s*,\s*)('1')""", r"\1'$1'", query)
print(query)
-# Calculate available memory to configurate SparkSession
-ram = int(round(psutil.virtual_memory().available / (1024 ** 3) * 0.7))
+# Calculate available memory to configurate SparkSession (in MB)
+ram = int(round(psutil.virtual_memory().available / (1024 ** 2) * 0.7))
heap = ram // 2
off_heap = ram - heap
-print(f"SparkSession will use {heap} GB of heap and {off_heap} GB of off-heap memory")
+print(f"SparkSession will use {heap} MB of heap and {off_heap} MB of off-heap memory (total {ram} MB)")
builder = (
SparkSession
.builder
.appName("ClickBench")
.config("spark.driver", "local[*]") # To ensure using all cores
- .config("spark.driver.memory", f"{heap}g") # Set amount of memory SparkSession can use
+ .config("spark.driver.memory", f"{heap}m")
.config("spark.sql.parquet.binaryAsString", True) # Treat binary as string to get correct length calculations and text results
# Additional Comet configuration
@@ -44,7 +41,7 @@
.config("spark.plugins", "org.apache.spark.CometPlugin")
.config("spark.shuffle.manager", "org.apache.spark.sql.comet.execution.shuffle.CometShuffleManager")
.config("spark.memory.offHeap.enabled", "true")
- .config("spark.memory.offHeap.size", f"{off_heap}g")
+ .config("spark.memory.offHeap.size", f"{off_heap}m")
.config("spark.comet.regexp.allowIncompatible", True)
.config("spark.comet.scan.allowIncompatible", True)
)
diff --git a/spark-gluten/README.md b/spark-gluten/README.md
index 03da87113..774c41653 100644
--- a/spark-gluten/README.md
+++ b/spark-gluten/README.md
@@ -1,13 +1,16 @@
-This README includes info on configuring Apache Gluten for ClickBench. For additional details, please refer to [Gluten's docs](https://apache.github.io/incubator-gluten/get-started/Velox.html) and [spark-accelerators README](../spark/README-accelerators.md).
+This README includes info on configuring Apache Gluten for ClickBench. For additional details, please refer to [Gluten's docs](https://apache.github.io/incubator-gluten/get-started/Velox.html), [spark-accelerators README](../spark/README-accelerators.md) and [discussion](https://github.com/apache/incubator-gluten/discussions/10465).
### Run
As usual, benchmark can be run via `./benchmark.sh`. Additionally, users can provide machine spec like `./benchmark.sh c6a.8xlarge` so script saves it in relevant file.
-### Notes
+## Notes
+
+### Links
- Check [here](https://gluten.apache.org/downloads/) for _pre-built jars_.
- Check [here](https://gluten.apache.org/#3-how-to-use) and [here](https://apache.github.io/incubator-gluten/get-started/Velox.html#submit-the-spark-sql-job) for _examples of Gluten configuration_.
+- Check [here](https://github.com/apache/incubator-gluten/blob/main/docs/velox-backend-scalar-function-support.md?plain=1) for _a list of (un-)supported expressions_.
### Configuration
@@ -16,7 +19,8 @@ As usual, benchmark can be run via `./benchmark.sh`. Additionally, users can pro
An error occurred while calling o59.showString.
: java.lang.NoSuchMethodError: 'scala.collection.Seq org.apache.spark.sql.execution.PartitionedFileUtil$.splitFiles(org.apache.spark.sql.SparkSession, org.apache.spark.sql.execution.datasources.FileStatusWithMetadata, boolean, long, org.apache.spark.sql.catalyst.InternalRow)'
```
-- While [documentation](https://gluten.apache.org/#3-how-to-use) recommends building Gluten from source, pre-compiled JAR is used to [avoid out-of-memory compilation issues](https://apache.github.io/incubator-gluten/get-started/Velox.html#build-gluten-with-velox-backend) on smaller machines:
+- While [documentation](https://gluten.apache.org/#3-how-to-use) recommends building Gluten from source, pre-compiled JAR is used. While it's done akin to other Spark engines, it also lets [avoid out-of-memory compilation issues](https://apache.github.io/incubator-gluten/get-started/Velox.html#build-gluten-with-velox-backend) on smaller machines:
> Notes: Building Velox may fail caused by OOM. You can prevent this failure by adjusting NUM_THREADS (e.g., export NUM_THREADS=4) before building Gluten/Velox. The recommended minimal memory size is 64G.
- Gluten requires a __dedicated off-heap memory pool__. Memory is split 50/50 between Spark heap and Gluten off-heap, similar to [official guidance](https://apache.github.io/incubator-gluten/get-started/Velox.html#submit-the-spark-sql-job).
- JVM option `-Dio.netty.tryReflectionSetAccessible=true` [is set](https://github.com/apache/incubator-gluten/issues/8207) to avoid `UnsupportedOperationException: sun.misc.Unsafe or java.nio.DirectByteBuffer.(long, int) not available` error.
+- Although Gluten supports `REGEXP_REPLACE` according to docs (check [Links](#links) section above) and physical plan (`ProjectExecTransformer` is used), query is still rewritten (`\1` -> `$1`) similar to other Spark engines. Otherwise Gluten returns incorrect results. It seems that Gluten-on-Velox here [replicates Spark's logic](https://github.com/kecookier/velox/blob/a5994c3b8548dc41045b0ca86c75e60fe4185678/velox/docs/functions/spark/regexp.rst?plain=1#L95) and supports Java's regex syntax. Gluten-on-Clickhouse will probably require [use of the original query](https://github.com/apache/incubator-gluten/issues/7545).
diff --git a/spark-gluten/queries.sql b/spark-gluten/queries.sql
index 31f65fc89..8fafcbcf9 100644
--- a/spark-gluten/queries.sql
+++ b/spark-gluten/queries.sql
@@ -26,7 +26,7 @@ SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime LIMIT
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY SearchPhrase LIMIT 10;
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime, SearchPhrase LIMIT 10;
SELECT CounterID, AVG(length(URL)) AS l, COUNT(*) AS c FROM hits WHERE URL <> '' GROUP BY CounterID HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
-SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '\1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '$1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
SELECT SUM(ResolutionWidth), SUM(ResolutionWidth + 1), SUM(ResolutionWidth + 2), SUM(ResolutionWidth + 3), SUM(ResolutionWidth + 4), SUM(ResolutionWidth + 5), SUM(ResolutionWidth + 6), SUM(ResolutionWidth + 7), SUM(ResolutionWidth + 8), SUM(ResolutionWidth + 9), SUM(ResolutionWidth + 10), SUM(ResolutionWidth + 11), SUM(ResolutionWidth + 12), SUM(ResolutionWidth + 13), SUM(ResolutionWidth + 14), SUM(ResolutionWidth + 15), SUM(ResolutionWidth + 16), SUM(ResolutionWidth + 17), SUM(ResolutionWidth + 18), SUM(ResolutionWidth + 19), SUM(ResolutionWidth + 20), SUM(ResolutionWidth + 21), SUM(ResolutionWidth + 22), SUM(ResolutionWidth + 23), SUM(ResolutionWidth + 24), SUM(ResolutionWidth + 25), SUM(ResolutionWidth + 26), SUM(ResolutionWidth + 27), SUM(ResolutionWidth + 28), SUM(ResolutionWidth + 29), SUM(ResolutionWidth + 30), SUM(ResolutionWidth + 31), SUM(ResolutionWidth + 32), SUM(ResolutionWidth + 33), SUM(ResolutionWidth + 34), SUM(ResolutionWidth + 35), SUM(ResolutionWidth + 36), SUM(ResolutionWidth + 37), SUM(ResolutionWidth + 38), SUM(ResolutionWidth + 39), SUM(ResolutionWidth + 40), SUM(ResolutionWidth + 41), SUM(ResolutionWidth + 42), SUM(ResolutionWidth + 43), SUM(ResolutionWidth + 44), SUM(ResolutionWidth + 45), SUM(ResolutionWidth + 46), SUM(ResolutionWidth + 47), SUM(ResolutionWidth + 48), SUM(ResolutionWidth + 49), SUM(ResolutionWidth + 50), SUM(ResolutionWidth + 51), SUM(ResolutionWidth + 52), SUM(ResolutionWidth + 53), SUM(ResolutionWidth + 54), SUM(ResolutionWidth + 55), SUM(ResolutionWidth + 56), SUM(ResolutionWidth + 57), SUM(ResolutionWidth + 58), SUM(ResolutionWidth + 59), SUM(ResolutionWidth + 60), SUM(ResolutionWidth + 61), SUM(ResolutionWidth + 62), SUM(ResolutionWidth + 63), SUM(ResolutionWidth + 64), SUM(ResolutionWidth + 65), SUM(ResolutionWidth + 66), SUM(ResolutionWidth + 67), SUM(ResolutionWidth + 68), SUM(ResolutionWidth + 69), SUM(ResolutionWidth + 70), SUM(ResolutionWidth + 71), SUM(ResolutionWidth + 72), SUM(ResolutionWidth + 73), SUM(ResolutionWidth + 74), SUM(ResolutionWidth + 75), SUM(ResolutionWidth + 76), SUM(ResolutionWidth + 77), SUM(ResolutionWidth + 78), SUM(ResolutionWidth + 79), SUM(ResolutionWidth + 80), SUM(ResolutionWidth + 81), SUM(ResolutionWidth + 82), SUM(ResolutionWidth + 83), SUM(ResolutionWidth + 84), SUM(ResolutionWidth + 85), SUM(ResolutionWidth + 86), SUM(ResolutionWidth + 87), SUM(ResolutionWidth + 88), SUM(ResolutionWidth + 89) FROM hits;
SELECT SearchEngineID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, ClientIP ORDER BY c DESC LIMIT 10;
SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
diff --git a/spark-gluten/query.py b/spark-gluten/query.py
index 63445a3a8..4d2c15d34 100755
--- a/spark-gluten/query.py
+++ b/spark-gluten/query.py
@@ -12,28 +12,25 @@
import pyspark.sql.functions as F
import psutil
-import re
import sys
import timeit
query = sys.stdin.read()
-# Replace \1 to $1 because spark recognizes only this pattern style (in query 28)
-query = re.sub(r"""(REGEXP_REPLACE\(.*?,\s*('[^']*')\s*,\s*)('1')""", r"\1'$1'", query)
print(query)
-# Calculate available memory to configurate SparkSession
-ram = int(round(psutil.virtual_memory().available / (1024 ** 3) * 0.7))
+# Calculate available memory to configurate SparkSession (in MB)
+ram = int(round(psutil.virtual_memory().available / (1024 ** 2) * 0.7))
heap = ram // 2
off_heap = ram - heap
-print(f"SparkSession will use {heap} GB of heap and {off_heap} GB of off-heap memory")
+print(f"SparkSession will use {heap} MB of heap and {off_heap} MB of off-heap memory (total {ram} MB)")
builder = (
SparkSession
.builder
.appName("ClickBench")
.config("spark.driver", "local[*]") # To ensure using all cores
- .config("spark.driver.memory", f"{heap}g") # Set amount of memory SparkSession can use
+ .config("spark.driver.memory", f"{heap}m")
.config("spark.sql.parquet.binaryAsString", True) # Treat binary as string to get correct length calculations and text results
# Additional Gluten configuration
@@ -42,7 +39,7 @@
.config("spark.plugins", "org.apache.gluten.GlutenPlugin")
.config("spark.shuffle.manager", "org.apache.spark.shuffle.sort.ColumnarShuffleManager")
.config("spark.memory.offHeap.enabled", "true")
- .config("spark.memory.offHeap.size", f"{off_heap}g")
+ .config("spark.memory.offHeap.size", f"{off_heap}m")
.config("spark.driver.extraJavaOptions", "-Dio.netty.tryReflectionSetAccessible=true")
)
diff --git a/spark/README.md b/spark/README.md
new file mode 100644
index 000000000..722667832
--- /dev/null
+++ b/spark/README.md
@@ -0,0 +1,6 @@
+This README includes info on configuring Apache Spark for ClickBench.
+
+## Notes
+
+- 29 query with `REGEXP_REPLACE` is changed: `\1` is replaced with `$1` since Spark here follows Java’s regex syntax. In Java, backreferences in replacement strings use `$1`, `$2`, etc.
+- `EventTime` and `EventDate` columns are transformed (see [#7](https://github.com/ClickHouse/ClickBench/issues/7) issue for details).
diff --git a/spark/queries.sql b/spark/queries.sql
index 31f65fc89..8fafcbcf9 100644
--- a/spark/queries.sql
+++ b/spark/queries.sql
@@ -26,7 +26,7 @@ SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime LIMIT
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY SearchPhrase LIMIT 10;
SELECT SearchPhrase FROM hits WHERE SearchPhrase <> '' ORDER BY EventTime, SearchPhrase LIMIT 10;
SELECT CounterID, AVG(length(URL)) AS l, COUNT(*) AS c FROM hits WHERE URL <> '' GROUP BY CounterID HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
-SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '\1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
+SELECT REGEXP_REPLACE(Referer, '^https?://(?:www\.)?([^/]+)/.*$', '$1') AS k, AVG(length(Referer)) AS l, COUNT(*) AS c, MIN(Referer) FROM hits WHERE Referer <> '' GROUP BY k HAVING COUNT(*) > 100000 ORDER BY l DESC LIMIT 25;
SELECT SUM(ResolutionWidth), SUM(ResolutionWidth + 1), SUM(ResolutionWidth + 2), SUM(ResolutionWidth + 3), SUM(ResolutionWidth + 4), SUM(ResolutionWidth + 5), SUM(ResolutionWidth + 6), SUM(ResolutionWidth + 7), SUM(ResolutionWidth + 8), SUM(ResolutionWidth + 9), SUM(ResolutionWidth + 10), SUM(ResolutionWidth + 11), SUM(ResolutionWidth + 12), SUM(ResolutionWidth + 13), SUM(ResolutionWidth + 14), SUM(ResolutionWidth + 15), SUM(ResolutionWidth + 16), SUM(ResolutionWidth + 17), SUM(ResolutionWidth + 18), SUM(ResolutionWidth + 19), SUM(ResolutionWidth + 20), SUM(ResolutionWidth + 21), SUM(ResolutionWidth + 22), SUM(ResolutionWidth + 23), SUM(ResolutionWidth + 24), SUM(ResolutionWidth + 25), SUM(ResolutionWidth + 26), SUM(ResolutionWidth + 27), SUM(ResolutionWidth + 28), SUM(ResolutionWidth + 29), SUM(ResolutionWidth + 30), SUM(ResolutionWidth + 31), SUM(ResolutionWidth + 32), SUM(ResolutionWidth + 33), SUM(ResolutionWidth + 34), SUM(ResolutionWidth + 35), SUM(ResolutionWidth + 36), SUM(ResolutionWidth + 37), SUM(ResolutionWidth + 38), SUM(ResolutionWidth + 39), SUM(ResolutionWidth + 40), SUM(ResolutionWidth + 41), SUM(ResolutionWidth + 42), SUM(ResolutionWidth + 43), SUM(ResolutionWidth + 44), SUM(ResolutionWidth + 45), SUM(ResolutionWidth + 46), SUM(ResolutionWidth + 47), SUM(ResolutionWidth + 48), SUM(ResolutionWidth + 49), SUM(ResolutionWidth + 50), SUM(ResolutionWidth + 51), SUM(ResolutionWidth + 52), SUM(ResolutionWidth + 53), SUM(ResolutionWidth + 54), SUM(ResolutionWidth + 55), SUM(ResolutionWidth + 56), SUM(ResolutionWidth + 57), SUM(ResolutionWidth + 58), SUM(ResolutionWidth + 59), SUM(ResolutionWidth + 60), SUM(ResolutionWidth + 61), SUM(ResolutionWidth + 62), SUM(ResolutionWidth + 63), SUM(ResolutionWidth + 64), SUM(ResolutionWidth + 65), SUM(ResolutionWidth + 66), SUM(ResolutionWidth + 67), SUM(ResolutionWidth + 68), SUM(ResolutionWidth + 69), SUM(ResolutionWidth + 70), SUM(ResolutionWidth + 71), SUM(ResolutionWidth + 72), SUM(ResolutionWidth + 73), SUM(ResolutionWidth + 74), SUM(ResolutionWidth + 75), SUM(ResolutionWidth + 76), SUM(ResolutionWidth + 77), SUM(ResolutionWidth + 78), SUM(ResolutionWidth + 79), SUM(ResolutionWidth + 80), SUM(ResolutionWidth + 81), SUM(ResolutionWidth + 82), SUM(ResolutionWidth + 83), SUM(ResolutionWidth + 84), SUM(ResolutionWidth + 85), SUM(ResolutionWidth + 86), SUM(ResolutionWidth + 87), SUM(ResolutionWidth + 88), SUM(ResolutionWidth + 89) FROM hits;
SELECT SearchEngineID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY SearchEngineID, ClientIP ORDER BY c DESC LIMIT 10;
SELECT WatchID, ClientIP, COUNT(*) AS c, SUM(IsRefresh), AVG(ResolutionWidth) FROM hits WHERE SearchPhrase <> '' GROUP BY WatchID, ClientIP ORDER BY c DESC LIMIT 10;
diff --git a/spark/query.py b/spark/query.py
index a58177dfd..268b60e71 100755
--- a/spark/query.py
+++ b/spark/query.py
@@ -8,25 +8,22 @@
import pyspark.sql.functions as F
import psutil
-import re
import sys
import timeit
query = sys.stdin.read()
-# Replace \1 to $1 because spark recognizes only this pattern style (in query 28)
-query = re.sub(r"""(REGEXP_REPLACE\(.*?,\s*('[^']*')\s*,\s*)('1')""", r"\1'$1'", query)
print(query)
-# Calculate available memory to configurate SparkSession
-ram = int(round(psutil.virtual_memory().available / (1024 ** 3) * 0.7))
-print(f"SparkSession will use {ram} GB of memory")
+# Calculate available memory to configurate SparkSession (in MB)
+ram = int(round(psutil.virtual_memory().available / (1024 ** 2) * 0.7))
+print(f"SparkSession will use {ram} MB of memory")
spark = (
SparkSession
.builder
.appName("ClickBench")
.config("spark.driver", "local[*]") # To ensure using all cores
- .config("spark.driver.memory", f"{ram}g") # Set amount of memory SparkSession can use
+ .config("spark.driver.memory", f"{ram}m") # Set amount of memory SparkSession can use
.config("spark.sql.parquet.binaryAsString", True) # Treat binary as string to get correct length calculations and text results
.getOrCreate()
)